A B C D E F G H I J K L M N O P Q R S T U V W Y Z _ 

A

A - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'A'
abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.Abortable
Abort the server or client.
abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.client.Admin
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.master.HMaster
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
abort(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
abort(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
Receive a notification and propagate it to the local coordinator
abort(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
Pass along the found abort notification to the listener
abort(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
The abort() call is asynchronous and each procedure must decide how to deal with that, if they want to be abortable.
abort(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Send an abort notification the specified procedure.
abort(long, boolean) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Send an abort notification the specified procedure.
abort(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureInMemoryChore
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Cause the server to exit without closing the regions it is serving, the log it is using and without notifying the master.
abort(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner.WarnOnlyAbortable
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
ABORT_ON_ERROR_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
ABORT_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
Abortable - Interface in org.apache.hadoop.hbase
Interface to support the aborting of a given server or client.
abortable - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
abortable - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Used to abort if a fatal error occurs
abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
abortCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
abortCacheFlush(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
Abort a cache flush.
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
abort a procedure
abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Abort a procedure
abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
abortProcedure(RpcController, MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Abort a procedure.
abortProcedure(String, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
Abort the procedure with the given name
abortProcedureAsync(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Abort a procedure but does not block and wait for it be completely removed.
abortProcedureAsync(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Abort a procedure but does not block and wait for it be completely removed.
abortProcedureResult(MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
abortProcess() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.MasterProcedureStoreListener
 
abortProcess() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureStoreListener
triggered when the store is not able to write out data.
abortServer(CoprocessorEnvironment, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
abortServer(String, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
abortWriter(T) - Method in class org.apache.hadoop.hbase.regionserver.compactions.AbstractMultiOutputCompactor
 
abortWriter(T) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
abortWriter(StoreFile.Writer) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
 
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
 
absoluteValueOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
AbstractByteRange - Class in org.apache.hadoop.hbase.util
An abstract implementation of the ByteRange API
AbstractByteRange() - Constructor for class org.apache.hadoop.hbase.util.AbstractByteRange
 
AbstractClientScanner - Class in org.apache.hadoop.hbase.client
Helper class for custom client scanners.
AbstractClientScanner() - Constructor for class org.apache.hadoop.hbase.client.AbstractClientScanner
 
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
 
AbstractDataBlockEncoder.AbstractEncodedSeeker(KeyValue.KVComparator, 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
 
AbstractHBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
A utility class that encapsulates SASL logic for RPC client.
AbstractHBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean) - Constructor for class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
Create a HBaseSaslRpcClient for an authentication method
AbstractHBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, 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
 
AbstractHFileReader - Class in org.apache.hadoop.hbase.io.hfile
Common functionality needed by all versions of HFile readers.
AbstractHFileReader(Path, FixedFileTrailer, long, CacheConfig, HFileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
AbstractHFileReader.BlockIndexNotLoadedException - Exception in org.apache.hadoop.hbase.io.hfile
 
AbstractHFileReader.BlockIndexNotLoadedException() - Constructor for exception org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.BlockIndexNotLoadedException
 
AbstractHFileReader.NotSeekedException - Exception in org.apache.hadoop.hbase.io.hfile
An exception thrown when an operation requiring a scanner to be seeked is invoked on a scanner that is not seeked.
AbstractHFileReader.NotSeekedException() - Constructor for exception org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.NotSeekedException
 
AbstractHFileReader.Scanner - Class in org.apache.hadoop.hbase.io.hfile
 
AbstractHFileReader.Scanner(HFile.Reader, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
AbstractHFileWriter - Class in org.apache.hadoop.hbase.io.hfile
Common functionality needed by all versions of HFile writers.
AbstractHFileWriter(CacheConfig, FSDataOutputStream, Path, KeyValue.KVComparator, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
 
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, Store) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.AbstractMultiOutputCompactor
 
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
 
AbstractRpcClient<T extends org.apache.hadoop.hbase.ipc.RpcConnection> - Class in org.apache.hadoop.hbase.ipc
Provides the basics for a RpcClient implementation like configuration and Logging.
AbstractRpcClient(Configuration, String, SocketAddress, MetricsConnection) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Construct an IPC client for the cluster clusterId
AbstractRpcClient.BlockingRpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
Blocking rpc channel that goes via hbase rpc.
AbstractRpcClient.BlockingRpcChannelImplementation(AbstractRpcClient<?>, InetSocketAddress, User, int) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
 
AbstractRpcClient.RpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
Async rpc channel that goes via hbase rpc.
AbstractRpcClient.RpcChannelImplementation(AbstractRpcClient<?>, InetSocketAddress, User, int) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
 
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
 
AbstractTerminalPrinter - Class in org.apache.hadoop.hbase.hbtop.terminal
 
AbstractTerminalPrinter() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.AbstractTerminalPrinter
 
accept(Field, List<Field>, EnumMap<Field, Boolean>) - Method in interface org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter.ResultListener
 
accept(Mode) - Method in interface org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter.ResultListener
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
Filters out a path.
accept(FileStatus) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
 
accept(Path) - 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, 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.HFileFilter
 
accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.HFileLinkFilter
 
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_POLICY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
The strategy for handling new accepted connections.
ACCEPT_QUEUE_SIZE_PER_THREAD_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
Maximum number of accepted elements per selector
access(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
Block has been accessed.
AccessChecker - Class in org.apache.hadoop.hbase.security.access
 
AccessChecker(Configuration, ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.security.access.AccessChecker
Constructor with existing configuration
AccessControlClient - Class in org.apache.hadoop.hbase.security.access
Utility client for doing access control admin operations.
AccessControlClient() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlClient
 
AccessControlConstants - Interface in org.apache.hadoop.hbase.security.access
 
AccessController - Class in org.apache.hadoop.hbase.security.access
Provides basic authorization checks for data access and administrative operations.
AccessController() - Constructor for class org.apache.hadoop.hbase.security.access.AccessController
 
AccessControlLists - Class in org.apache.hadoop.hbase.security.access
Maintains lists of permission grants to users and groups to allow for authorization checks by AccessController.
AccessControlLists() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlLists
 
AccessDeniedException - Exception in org.apache.hadoop.hbase.security
Exception thrown by access-related methods.
AccessDeniedException() - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(Throwable) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
ACL_GLOBAL_NAME - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
 
ACL_KEY_DELIMITER - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
Delimiter to separate user, column family, and qualifier in _acl_ table info: column keys
ACL_LIST_FAMILY - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
 
ACL_LIST_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
Column family used to store ACL grants
ACL_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlClient
 
ACL_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
Internal storage table for access control lists
ACL_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
KV tag to store per cell access control lists
ACL_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
 
acquire() - Method in interface org.apache.hadoop.hbase.InterProcessLock
Acquire the lock, waiting indefinitely until the lock is released or the thread is interrupted.
acquire() - Method in interface org.apache.hadoop.hbase.master.TableLockManager.TableLock
Acquire the lock, with the configured lock timeout.
acquire() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Acquire the lock, waiting indefinitely until the lock is released or the thread is interrupted.
acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
Flush the online regions on this rs for the target table.
acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.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.
ACQUIRED_BARRIER_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
acquireDelegationToken(FileSystem) - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
Acquire the delegation token for the specified filesytem.
acquiredLock - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
 
acquiredZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
acquireLock(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
The user should override this method, and try to take a lock if necessary.
acquireLock(K) - Method in class org.apache.hadoop.hbase.util.KeyLocker
Return a lock for the given key.
acquireLocks(Set<? extends K>) - Method in class org.apache.hadoop.hbase.util.KeyLocker
Acquire locks for a set of keys.
acquireRegionLock(String) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
To avoid racing with AM, external entities may need to lock a region, for example, when SSH checks what regions to skip re-assigning.
Action<R> - Class in org.apache.hadoop.hbase.client
A Get, Put, Increment, Append, or Delete associated with it's region.
Action(Row, int) - Constructor for class org.apache.hadoop.hbase.client.Action
 
Action(Row, int, int) - Constructor for class org.apache.hadoop.hbase.client.Action
 
Action(Action<R>, int) - Constructor for class org.apache.hadoop.hbase.client.Action
Creates an action for a particular replica from original action.
ACTION_BY_CODE - Static variable in class org.apache.hadoop.hbase.security.access.Permission
 
actions - Variable in class org.apache.hadoop.hbase.client.MultiAction
 
actions - Variable in class org.apache.hadoop.hbase.security.access.Permission
 
activateOptions() - Method in class org.apache.hadoop.hbase.AsyncConsoleAppender
 
ACTIVE_WORKER_COUNT_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
ActiveMasterManager - Class in org.apache.hadoop.hbase.master
Handles everything on master-side related to master election.
activeOperations - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
actualErrorRate() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
Computes the error rate for this Bloom filter, taking into account the actual number of hash functions and keys inserted.
actualErrorRate(long, long, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
Computes the actual error rate for the given number of elements, number of bits, and number of hash functions.
AdaptiveLifoCoDelCallQueue - Class in org.apache.hadoop.hbase.ipc
Adaptive LIFO blocking queue utilizing CoDel algorithm to prevent queue overloading.
AdaptiveLifoCoDelCallQueue(int, int, int, double, AtomicLong, AtomicLong) - Constructor for class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
Add the specified column and value to this Append operation.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Append
Add column and value to this Append operation.
add(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
add(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
add(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
add(Map.Entry<byte[], List<Action<T>>>) - Method in class org.apache.hadoop.hbase.client.DelayingRunner
 
add(Cell) - Method in class org.apache.hadoop.hbase.client.Increment
Add the specified KeyValue to this operation.
add(byte[], Action<R>) - Method in class org.apache.hadoop.hbase.client.MultiAction
Add an Action to this container based on it's regionName.
add(byte[], List<Action<R>>) - Method in class org.apache.hadoop.hbase.client.MultiAction
Add an Action to this container based on it's regionName.
add(byte[], int, Object) - Method in class org.apache.hadoop.hbase.client.MultiResponse
Add the pair to the container, grouped by the regionName
add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
add(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
add(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
add(Cell) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified KeyValue to this Put operation.
add(Put) - Method in class org.apache.hadoop.hbase.client.RowMutations
Add a Put operation to the list of mutations
add(Delete) - Method in class org.apache.hadoop.hbase.client.RowMutations
Add a Delete operation to the list of mutations
add(byte) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
methods
add(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
methods
add(Configuration) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
Add Hadoop Configuration object to config list.
add(HTableDescriptor, Class<? extends Constraint>...) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Add configuration-less constraints to the table.
add(HTableDescriptor, Pair<Class<? extends Constraint>, Configuration>...) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Add constraints and their associated configurations to the table.
add(HTableDescriptor, Class<? extends Constraint>, Configuration) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Add a Constraint to the table with the given configuration
add(S, S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
add(HDFSBlocksDistribution) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
This will add the distribution from input to this object
add(Map.Entry<BlockCacheKey, BucketCache.BucketEntry>) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
Attempt to add the specified entry to this queue.
add(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
Attempt to add the specified cached block to this queue.
add(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
add(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
Adds the server to the dead server list if it's not there already.
add(long, long) - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
Adds a value to the histogram.
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(E) - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
 
add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Write an update
add(Iterable<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
 
add(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
Add the specified cell to the list of deletes to check against for this row operation.
add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
add(Iterable<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
add(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Write an update
add(Iterable<Cell>) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Write the updates
add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
Add the specified KeyValue to the list of deletes to check against for this row operation.
add(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Adds a value to the memstore
add(Iterable<Cell>) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Adds the specified value to the memstore
add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
add(String) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
Add a node to the cluster
add(String, int) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
Add a node to the cluster
add(TableRegionModel) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
Add a region model to the list
add(TableModel) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
Add the table name model to the list
add(Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
 
add(HTableDescriptor) - Method in interface org.apache.hadoop.hbase.TableDescriptors
Add or update descriptor
add(Runnable) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
add(DataType<?>) - Method in class org.apache.hadoop.hbase.types.StructBuilder
Append field to the sequence of accumulated fields.
add(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
Add the specified binary to the bloom filter.
add(byte[]) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
add(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
add(ByteRange) - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
Check if the incoming byte range exists.
add(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
add(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
add(byte[][]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
add(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
Adds a Bloom filter key.
add(long) - Method in class org.apache.hadoop.hbase.util.Counter
 
add(long, long) - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
Adds a value to the histogram.
add(HTableDescriptor) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Adds (or updates) the table descriptor to the FileSystem and updates the local cache with it.
add(long) - Method in class org.apache.hadoop.hbase.util.LongAdder
Adds the given value.
add(String) - Method in class org.apache.hadoop.hbase.util.LossyCounting
 
add(R) - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
Adds an edge to the split calculator
add(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
add(E) - Method in class org.apache.hadoop.hbase.util.SortedList
 
add(int, E) - Method in class org.apache.hadoop.hbase.util.SortedList
 
add(String, long) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Add sample to a stat metric by name.
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.
addAll(ArrayList<ByteRange>) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
building
addAll(Collection<? extends CallRunner>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
addAll(Collection<? extends Cell>) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
addAll(Collection<? extends Runnable>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
addAll(Collection<? extends E>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
addAll(Collection<? extends E>) - Method in class org.apache.hadoop.hbase.util.SortedList
 
addAll(int, Collection<? extends E>) - Method in class org.apache.hadoop.hbase.util.SortedList
 
addAllAttrs(Iterable<? extends ColumnSchemaMessage.ColumnSchema.Attribute>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
addAllAttrs(Iterable<? extends TableSchemaMessage.TableSchema.Attribute>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
addAllColumns(Iterable<? extends ByteString>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated bytes columns = 3;
addAllColumns(Iterable<? extends ColumnSchemaMessage.ColumnSchema>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
addAllDeadNodes(Iterable<String>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated string deadNodes = 2;
addAllLabels(Iterable<String>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated string labels = 10;
addAllLiveNodes(Iterable<? extends StorageClusterStatusMessage.StorageClusterStatus.Node>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
addAllName(Iterable<String>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
repeated string name = 1;
addAllNamespace(Iterable<String>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
repeated string namespace = 1;
addAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
addAllProps(Iterable<? extends NamespacePropertiesMessage.NamespaceProperties.Property>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
addAllRegions(Iterable<? extends StorageClusterStatusMessage.StorageClusterStatus.Region>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
addAllRegions(Iterable<? extends TableInfoMessage.TableInfo.Region>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
addAllRows(Iterable<? extends CellSetMessage.CellSet.Row>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
addAllServers(Collection<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Adds a group of servers.
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
 
addAllValues(Iterable<? extends CellMessage.Cell>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
addAndGetGlobalMemstoreSize(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Increase the size of mem store in this region and the size of global mem store
addAndGetGlobalMemstoreSize(long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
 
addAndGetRegionReplayEditsSize(byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
Add memStoreSize to replayEditsPerRegion.
addAttribute(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
addAttrs(ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
addAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
addAttrs(ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
addAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
addAttrs(TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
addAttrs(int, TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
addAttrs(TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
addAttrs(int, TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
addAttrsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
addAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
addAttrsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
addAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
addBack(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
addBack(Procedure) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
Inserts the specified element at the end of this queue.
addBack(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
 
addCallSize(long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
addCallSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
Add/subtract from the current size of all outstanding calls.
addCell(CellModel) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
Adds a cell to the list of cells for this row
addChangedReaderObserver(ChangedReadersObserver) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
addChangedReaderObserver(ChangedReadersObserver) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
addChild(TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
addChildExp(ExpressionNode) - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
 
addChildExps(List<ExpressionNode>) - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
 
addChildProcedure(Procedure...) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
Add a child procedure to execute
addChore(ProcedureInMemoryChore) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Add a chore procedure to the executor
addClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
Add a client port to the list.
addClusterId(UUID) - Method in class org.apache.hadoop.hbase.wal.WALKey
Marks that the cluster with the given clusterId has consumed the change
addColumn(TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a column to an existing table.
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the latest version of the specified column.
addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the specified version of the specified column.
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Get
Get the column from the specific family with the specified qualifier.
addColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Add a column to an existing table.
addColumn(String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Add a column to an existing table.
addColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Add a column to an existing table.
addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Increment
Increment the column from the specific family with the specified qualifier by the specified amount.
addColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value to this Put operation.
addColumn(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value, with the specified timestamp as its version to this Put operation.
addColumn(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value, with the specified timestamp as its version to this Put operation.
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get the column from the specified family with the specified qualifier.
addColumn(TableName, HColumnDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
addColumn(RpcController, MasterProtos.AddColumnRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
addColumn(TableName, HColumnDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Add a new column to an existing table
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
 
addColumnFamily(ColumnSchemaModel) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
Add a column family to the table descriptor
AddColumnFamilyProcedure - Class in org.apache.hadoop.hbase.master.procedure
The procedure to add a column family to an existing table.
AddColumnFamilyProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
AddColumnFamilyProcedure(MasterProcedureEnv, TableName, HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
addColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column.
addColumns(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column with a timestamp less than or equal to the specified timestamp.
addColumns(Scan, byte[][]) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Adds an array of columns specified using old format, family:qualifier.
addColumns(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated bytes columns = 3;
addColumns(ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
addColumns(int, ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
addColumns(ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
addColumns(int, ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
addColumnsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
addColumnsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
addCompactionResults(Collection<StoreFile>, Collection<StoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Adds only the new compaction results into the structure.
addCompactionResults(Collection<StoreFile>, Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
addConfiguration(Map<String, String>) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
addConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
addContext(Context, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
 
addContext(String, String, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add a context
addCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Add a table coprocessor to this table.
addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Add a table coprocessor to this table.
addCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Add a table coprocessor to this table.
addCurrentScanners(List<? extends KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
addDaughter(Connection, HRegionInfo, ServerName, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a daughter region entry to meta.
addDaughtersToPut(Put, HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds split daughters to the Put
addDeadNode(String) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
Add a dead node to the cluster representation.
addDeadNodes(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated string deadNodes = 2;
addDeadNodesBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated string deadNodes = 2;
addDefaultApps(ContextHandlerCollection, String, Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add default apps.
addDefaultServlets(ContextHandlerCollection) - 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.HFileWriterV2
 
addDeleteMarker(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
Advanced use only.
addDependencyJars(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
addDependencyJars(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Add the HBase dependency jars as well as jars for any of the configured job classes to the job configuration, so that JobClient will ship them to the cluster and add them to the DistributedCache.
addDependencyJars(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Deprecated.
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.
addEmptyLocation(Put, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addEndpoint(URI) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
Add an endpoint that the HTTP server should listen to.
addEntry(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Add one index entry to the current leaf-level block.
addEntry(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
Adds an entry to the dictionary.
addEntry(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
 
addException(byte[], Throwable) - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
addExtraHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Add extra headers.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of all columns of the specified family.
addFamily(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all columns of the specified family with a timestamp less than or equal to the specified timestamp.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Get
Get all columns from the specified family.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get all columns from the specified family.
addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
Does NOT add a column family.
addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Adds a column family.
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.
addFileInfoToException(IOException) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
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.
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
 
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, Context) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add the path spec to the filter path mapping.
addFront(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
addFront(Procedure) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
Inserts the specified element at the front of this queue.
addFront(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
 
addGeneralBloomFilter(BloomFilterWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
Store general Bloom filter in the file.
addGeneralBloomFilter(BloomFilterWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
 
addGetResult(Result) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
addGetResult(Result) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Add a get result.
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(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
 
addHFileRefs(String, List<Pair<Path, Path>>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Add new hfile references to the queue.
addHFileRefs(String, List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
addHostsAndBlockWeight(String[], long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
add some weight to a list of hosts, update the value of unique block weight
addImmutable(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
addImmutable(byte[], byte[], byte[], Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
This expects that the underlying arrays won't change.
addImmutable(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
addImmutable(byte[], byte[], long, byte[], Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
This expects that the underlying arrays won't change.
addImmutable(byte[], ByteBuffer, long, ByteBuffer, Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
This expects that the underlying arrays won't change.
addImmutable(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
addInfo(String, SecurityInfo) - Static method in class org.apache.hadoop.hbase.security.SecurityInfo
Adds a security configuration for a new service name.
addInlineBlockWriter(InlineBlockWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
Adds an inline block writer such as a multi-level block index writer or a compound Bloom filter writer.
addInlineBlockWriter(InlineBlockWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
 
addInternalServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add an internal servlet in the server.
addInternalServlet(String, String, Class<? extends HttpServlet>, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add an internal servlet in the server, specifying whether or not to protect with Kerberos authentication.
addJerseyResourcePackage(String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add a Jersey resource package.
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(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated string labels = 10;
addLabels(List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
addLabels(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.
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 interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
Adds the set of labels into the system.
addLabelsBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated string labels = 10;
addLease(Leases.Lease) - Method in class org.apache.hadoop.hbase.regionserver.Leases
Inserts lease.
addListener(ForeignExceptionListener) - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
Listen for failures to a given process.
addListener(ReplicationPeerConfigListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerConfigTracker
 
addLiveNode(String, long, int, int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
Add a live node to the cluster representation.
addLiveNodes(StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
addLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
addLiveNodes(StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
addLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
addLiveNodesBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
addLiveNodesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
addLocation(Put, ServerName, long, long, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addLocation(Put, ServerName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
 
addLocation(Put, ServerName, long) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
 
addLocationsOrderInterceptor(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
 
addLog(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Add a new WAL file to the given queue.
addLog(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
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
 
addMetaWALSplit(long, long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
Record a single instance of a split
addMutation(Mutation) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
addMutation(Mutation) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Add a mutation result.
addMvccToOperationContext(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
Store the write point in OperationContext when the operation succeed.
addName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
repeated string name = 1;
addNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
repeated string name = 1;
addNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
 
addNamespace(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
repeated string namespace = 1;
addNamespaceBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
repeated string namespace = 1;
addNamespaceQuota(Connection, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addNode(TokenizerNode, int, int, ByteRange, int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
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.
addOption(Option) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
addOptions() - Method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
 
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.
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
 
addPeer(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
Use addPeer(String, ReplicationPeerConfig, Map) instead.
addPeer(String, String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
addPeer(String, ReplicationPeerConfig, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Add a new remote slave cluster for replication.
addPeer(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Add a new remote slave cluster for replication.
addPeer(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Add a new remote slave cluster for replication.
addPeer(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
addPeerToHFileRefs(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Add a peer to hfile reference queue if peer does not exist.
addPeerToHFileRefs(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
addPlan(String, RegionPlan) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Add a regionPlan for the specified region.
addPlans(Map<String, RegionPlan>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Add a map of region plans.
addProperty(String, String) - Method in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
Add property to the namespace.
addProps(NamespacePropertiesMessage.NamespaceProperties.Property) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
addProps(int, NamespacePropertiesMessage.NamespaceProperties.Property) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
addProps(NamespacePropertiesMessage.NamespaceProperties.Property.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
addProps(int, NamespacePropertiesMessage.NamespaceProperties.Property.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
addPropsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
addPropsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
addPushSize(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
Add current size to the current cycle's total push size
addPutToKv(Put, Cell) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
 
addRegion(byte[], int, int, int, int, int, long, long, int, int, int, long, long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
Add a region name to the list
addRegion(HRegion) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Creates a 'manifest' for the specified region, by reading directly from the HRegion object.
addRegion(HRegion, SnapshotManifest.RegionVisitor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
addRegion(Path, HRegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Creates a 'manifest' for the specified region, by reading directly from the disk.
addRegion(Path, HRegionInfo, SnapshotManifest.RegionVisitor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
addRegionInfo(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
 
addRegions(StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
addRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
addRegions(StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
addRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
addRegions(TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
addRegions(int, TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
addRegions(TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
addRegions(int, TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
addRegionsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
addRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
addRegionsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
addRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
addRegionServer() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addRegionServer(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addRegionServer(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addRegionsToMeta(List<HRegionInfo>, int) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
Add the specified set of regions to the hbase:meta table.
addRegionsToMeta(MasterProcedureEnv, HTableDescriptor, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
Add the specified set of regions to the hbase:meta table.
addRegionsToMeta(List<HRegionInfo>, int) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
 
addRegionsToMeta(Connection, List<HRegionInfo>, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for each of the specified new regions.
addRegionsToMeta(Connection, List<HRegionInfo>, int, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for each of the specified new regions.
addRegionToMeta(Connection, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for the specified new region.
addRegionToMeta(Table, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for the specified new region to the given catalog table.
addRegionToMeta(Table, HRegionInfo, HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a (single) hbase:meta row for the specified new region and its daughters.
addRegionToMeta(Connection, HRegionInfo, HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a (single) hbase:meta row for the specified new region and its daughters.
addRegionToMETA(HRegion, HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Inserts a new region's meta information into the passed meta region.
addRegionToSnapshot(HBaseProtos.SnapshotDescription, ForeignExceptionSnare) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Complete taking the snapshot on the region.
addReplicas(HTableDescriptor, List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
Create any replicas for the regions (the default replicas that was already created is passed to the method)
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
 
address - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
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).
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
addResults(ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.Result
addRow(RowModel) - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
Add a row to this cell set
addRows(CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
addRows(int, CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
addRows(CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
addRows(int, CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
addRowsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
addRowsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
addRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Creates a new RegionServer group with the given name.
addRSGroup(RpcController, RSGroupAdminProtos.AddRSGroupRequest, RpcCallback<RSGroupAdminProtos.AddRSGroupResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
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
Adds the group.
addScanner(ResultScanner, boolean) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Assigns a unique ID to the scanner and adds the mapping to an internal hash-map.
addScanResult(List<Result>) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
addScanResult(List<Result>) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Add a scan result.
addSequenceNum(Put, long, long, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Adds the server to the group.
addServer(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
addServer(ServerName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
 
addServerToDrainList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
addServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add a servlet in the server.
addServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.InfoServer
 
addShutdownHook(Thread, int) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
 
addSnapshot(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshot
Record a single instance of a snapshot
addSnapshotClone(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshot
Record a single instance of a snapshot cloned table
addSnapshotRestore(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshot
Record a single instance of a snapshot
addSorted(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
addSorted(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
building
addSource(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Add sources for the given peer cluster on this region server.
addSplit(long, long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
Record a single instance of a split
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
 
addStringMap(Map<String, String>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
Add String map to config list.
addSublist(List<T>) - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
 
addSystemLabel(Region, Map<String, Integer>, Map<String, List<Integer>>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
addTable(String) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
Add the named table to be those being archived.
addTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
addTableDescriptor(HTableDescriptor) - 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
 
addTableToMeta(MasterProcedureEnv, HTableDescriptor, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
addToColumnFamilies(ColumnDescriptor) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
addToColumns(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
addToColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
addToColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
addToColumns(TColumnIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
addToColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
addToColumnValues(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
addToColumnValues(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
addToCounter(String, long) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
addToFailedServers(InetSocketAddress, Throwable) - Method in class org.apache.hadoop.hbase.ipc.FailedServers
Add an address to the list of the failed servers list.
addToHDFSBlocksDistribution(HDFSBlocksDistribution, BlockLocation[]) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Update blocksDistribution with blockLocations
addToIncrements(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
addToken(Token<? extends TokenIdentifier>) - Method in class org.apache.hadoop.hbase.security.User
Adds the given Token to the user's credentials.
addTokenForJob(Connection, JobConf, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Checks for an authentication token for the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job.
addTokenForJob(Connection, User, Job) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Checks for an authentication token for the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job.
addTokenIfMissing(Connection, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Checks if an authentication tokens exists for the connected cluster, obtaining one if needed and adding it to the user's credentials.
addToLabels(String) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
addToMovedRegions(String, ServerName, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
addToMutations(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
addToMutations(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
addToMutations(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
addToMutations(TMutation) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
addToOnlineRegions(Region) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
addToOnlineRegions(Region) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
Add to online regions.
addToRowBatches(BatchMutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
addToRowBatches(BatchMutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
addToRows(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
addToRows(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
addToRows(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
addToRows(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
addToSortedColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
addToSortedRanges() - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
abstract
addToSortedRanges() - Method in class org.apache.hadoop.hbase.util.byterange.impl.ByteRangeHashSet
 
addToSortedRanges() - Method in class org.apache.hadoop.hbase.util.byterange.impl.ByteRangeTreeSet
 
addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
addToSuccess(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
addToSuccess(TRegionInfo) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
addToSuccess(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
addToSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
addToSuccess(THRegionLocation) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
addToSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
addToSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
addToSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
addToTdeletes(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
addToTgets(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
addToTgets(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
addToTputs(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
addToValues(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
addTypeFilter(QuotaType) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Add a type to the filter list
addUserQuota(Connection, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addUserQuota(Connection, String, TableName, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addUserQuota(Connection, String, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addValues(CellMessage.Cell) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
addValues(int, CellMessage.Cell) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
addValues(CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
addValues(int, CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
addValuesBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
addValuesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
addWAL(WAL) - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
 
addWeight(long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
add weight
addWritableMap(Map<ImmutableBytesWritable, ImmutableBytesWritable>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
Add ImmutableBytesWritable map to config list.
adjustFieldLength() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
Admin - Interface in org.apache.hadoop.hbase.client
The administrative API for HBase.
admin - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
Admin.MasterSwitchType - Enum in org.apache.hadoop.hbase.client
Deprecated.
ADMIN_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
AdminAuthorizedServlet - Class in org.apache.hadoop.hbase.http
General servlet which is admin-authorized.
AdminAuthorizedServlet() - Constructor for class org.apache.hadoop.hbase.http.AdminAuthorizedServlet
 
ADMINS_ACL - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
advance() - Method in interface org.apache.hadoop.hbase.CellScanner
Advance the scanner 1 cell.
advance() - Method in class org.apache.hadoop.hbase.client.Result
 
advance() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
 
advance() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
advance() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
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
 
afterCreatingZigZagLatch() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
Used to manufacture race condition reliably.
afterExecute() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
Called after compaction is executed by CompactSplitThread; for use by coproc subclasses.
afterExecute(Runnable, Throwable) - Method in class org.apache.hadoop.hbase.thrift.THBaseThreadPoolExecutor
 
afterLast - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
afterProcess(EventHandler) - Method in interface org.apache.hadoop.hbase.executor.EventHandler.EventHandlerListener
Called after any event is processed
AgeSnapshot - Class in org.apache.hadoop.hbase.io.hfile
Snapshot of block cache age in cache.
AggregateImplementation<T,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,R extends com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.coprocessor
A concrete AggregateProtocol implementation.
AggregateImplementation() - Constructor for class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
 
AggregationClient - Class in org.apache.hadoop.hbase.client.coprocessor
This client class is for invoking the aggregate functions deployed on the Region Server side via the AggregateService.
AggregationClient(Configuration) - Constructor for class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
Constructor with Conf object
align(int) - Static method in class org.apache.hadoop.hbase.util.ClassSize
Aligns a number to 8.
align(long) - Static method in class org.apache.hadoop.hbase.util.ClassSize
Aligns a number to 8.
ALL_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
Define for 'return-all-versions'.
allocate() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
Allocate a block in this bucket, return the offset representing the position in physical space
allocateBlock(int) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
Allocate a block with specified size.
allocateBytes(int) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
Allocate a slice of the given length.
allocateBytes(int) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
Allocate a slice of the given length.
allocBloom() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
Allocate memory for the bloom filter data.
allocBloom() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
allocBloom() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
 
allow(String, String, User, Permission.Action, String) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
 
allow(String, String, User, Permission.Action, TableName, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
 
allow(String, String, User, Permission.Action, TableName, Map<byte[], ? extends Collection<?>>) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
 
allowedFailures - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
allSameType - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
 
allSameType - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
allTableRegions(Configuration, Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
allTableRegions(Connection, TableName) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Lists all of the table regions currently in META.
allTypes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
AlreadyExists - Exception in org.apache.hadoop.hbase.thrift.generated
 
AlreadyExists() - Constructor for exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
AlreadyExists(String) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
AlreadyExists(AlreadyExists) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
Performs a deep copy on other.
AlreadyExists._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ammount - Variable in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
amount - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
AND - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
AND Byte Array
AND_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
AND Array
AND_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
AND_OPERATOR - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
annotatedQos - Variable in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
 
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
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.
ap - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
APP_DIR - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
appDir - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
Append - Class in org.apache.hadoop.hbase.client
Performs Append operations on a single row.
Append(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Append
Create a Append operation for the specified row.
Append(Append) - Constructor for class org.apache.hadoop.hbase.client.Append
Copy constructor
Append(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Append
Create a Append operation for the specified row.
append(Append) - Method in class org.apache.hadoop.hbase.client.HTable
Appends values to one or more columns within a single row.
append(Append) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
append(Append) - Method in interface org.apache.hadoop.hbase.client.Table
Appends values to one or more columns within a single row.
append(LoggingEvent) - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
 
append(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
Append the given key/value pair to the file info, optionally checking the key prefix.
append(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
 
append(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Add key/value to file.
append(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
Add key/value to file.
append(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.Compactor.CellSink
 
append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
 
append(Append) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
append(Append, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
append(Append, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Perform one or more append operations on a row.
append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
 
append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
 
append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
 
append(HTableDescriptor, HRegionInfo, WALKey, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
append(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
append(Append) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
append - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
The single append operation to apply
append(TAppend, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
append(TAppend, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
append(TAppend) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
append(TAppend) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Appends values to one or more columns within a single row.
append(TAppend) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
append(ByteBuffer, TAppend, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
append(ByteBuffer, TAppend, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
append(ByteBuffer, TAppend) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
append(ByteBuffer, TAppend) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
 
append(ByteBuffer, TAppend) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
append(HTableDescriptor, HRegionInfo, WALKey, WALEdit, boolean) - Method in interface org.apache.hadoop.hbase.wal.WAL
Append a set of edits to the WAL.
append(WAL.Entry) - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
 
append(WALSplitter.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
APPEND_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 interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
 
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
 
appendCurrentTokenToRowBuffer() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
helper methods
appendEntry(WAL.Entry) - Method in class org.apache.hadoop.hbase.wal.WALSplitter.EntryBuffers
Append a log entry into the corresponding region buffer.
appendFileInfo(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Add to the file info.
appendFileInfo(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
Add an element to the file info map.
appendFileInfo(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
 
appendFromThrift(TAppend) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
From a TAppend create an Append.
appendFromThrift(TAppend) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
 
appendKeyTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
appendKeyValue(StringBuilder, String, Object) - Static method in class org.apache.hadoop.hbase.util.Strings
Append to a StringBuilder a key/value.
appendKeyValue(StringBuilder, String, Object, String, String) - Static method in class org.apache.hadoop.hbase.util.Strings
Append to a StringBuilder a key/value.
appendMetaBlock(String, Writable) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
 
appendMetaBlock(String, Writable) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Add a meta block to the end of the file.
appendMetadata(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
Writes meta data.
appendMetadata(long, boolean, Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
Writes meta data.
appendNodes(List<TokenizerNode>, boolean, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
appendNodesToExternalList(List<TokenizerNode>, boolean, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
moving nodes around
appendOutputArrayOffsets(List<Integer>) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
appendOutputArrayOffsets(List<Integer>) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
appendPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Append the replicable table-cf config of the specified peer
appendPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Append the replicable table-cf config of the specified peer
appendStrings(StringBuilder, String...) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
 
appendThreadInfo(StringBuilder, ThreadInfo, String) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
Print all of the thread's information and stack traces.
appendToByteArray(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
copy key and value
appendToByteBuffer(ByteBuffer, KeyValue, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
appendTokenAndRepointByteRange(ByteRange, int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
appendToRowBuffer(byte) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
appendTrackedTimestampsToMetadata() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
Add TimestampRange and earliest put timestamp to Metadata
appendTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
apply(String) - Method in interface org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter.ResultListener
 
apply(byte) - Method in enum org.apache.hadoop.hbase.util.Order
Apply order to the byte val.
apply(byte[]) - Method in enum org.apache.hadoop.hbase.util.Order
Apply order to the byte array val.
apply(byte[], int, int) - Method in enum org.apache.hadoop.hbase.util.Order
Apply order to a range within the byte array val.
applyBatch(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
Convience method to change metrics when a batch of operations are applied.
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.
applyCompactionPolicy(ArrayList<StoreFile>, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExploringCompactionPolicy
 
applyCompactionPolicy(List<StoreFile>, boolean, boolean, int, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExploringCompactionPolicy
 
applyCompactionPolicy(ArrayList<StoreFile>, 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.
archiveFamily(FileSystem, Configuration, HRegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Remove from the specified region the store files of the specified column family, either by archiving them or outright deletion
archiveMetaLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
For meta region open and closed normally on a server, it may leave some meta WAL in the server's wal dir.
archiveRegion(Configuration, FileSystem, HRegionInfo) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Cleans up all the files for a HRegion by archiving the HFiles to the archive directory
archiveRegion(FileSystem, Path, Path, Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Remove an entire region from the table directory via archiving the region's hfiles.
archiveStoreFile(Configuration, FileSystem, HRegionInfo, Path, byte[], Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Archive the store file
archiveStoreFiles(Configuration, FileSystem, HRegionInfo, Path, byte[], Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Remove the store files, either by archiving them or outright deletion
areAdjacent(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Check whether two regions are adjacent
areAllSameType() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
get/set
areBuffersBigEnough() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
Call when first accessing a block.
areDeadServersInProgress() - Method in class org.apache.hadoop.hbase.master.DeadServer
Checks if there are currently any dead servers being processed by the master.
areDeadServersInProgress() - Method in class org.apache.hadoop.hbase.master.ServerManager
Checks if any dead servers are currently in progress.
areKeyLengthsEqual(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
lengths
arePartsEqual(ByteBuffer, int, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Check whether two parts in the same buffer are equal.
areRowLengthsEqual(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
 
areScanStartRowAndStopRowEqual(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientUtil
 
areSomeRegionReplicasColocated(BaseLoadBalancer.Cluster) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Subclasses should implement this to return true if the cluster has nodes that hosts multiple replicas for the same region, or, if there are multiple racks and the same rack hosts replicas of the same region
areSomeRegionReplicasColocated(BaseLoadBalancer.Cluster) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
areWritesEnabled() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
areWritesEnabled() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
areWritesEnabled() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
ARRAY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Array overhead
ARRAYLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ArrayList(0)
arrayOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
transient fields
ArraySearcherPool - Class in org.apache.hadoop.hbase.codec.prefixtree.decode
Pools PrefixTreeArraySearcher objects.
ArraySearcherPool() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.ArraySearcherPool
 
ArrayUtils - Class in org.apache.hadoop.hbase.util
A set of array utility functions that return reasonable values in cases where an array is allocated or if it is null
ArrayUtils() - Constructor for class org.apache.hadoop.hbase.util.ArrayUtils
 
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
 
arrowLeft() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
arrowLeft() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
arrowRight() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
arrowRight() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
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
 
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
 
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
 
asList(byte[], int, int) - Static method in class org.apache.hadoop.hbase.Tag
Creates the list of tags from the byte array b.
asLong() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
assertBulkLoadHFileOk(Path) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
assertBulkLoadHFileOk(Path) - Method in interface org.apache.hadoop.hbase.regionserver.Store
This throws a WrongRegionException if the HFile does not fit in this region, or an InvalidHFileException if the HFile is not valid.
assertSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
assertSnapshotRequestIsValid(HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
Check to make sure that the description of the snapshot requested is valid
assign(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
 
assign(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
assign(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Assigns the specified region.
assign(HRegionInfo, boolean, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Use care with forceNewPlan.
assign(RegionState, boolean, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Caller must hold lock on the passed state object.
assign(Map<HRegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Assigns specified regions retaining assignments, if any.
assign(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Assigns specified regions round robin, if any.
ASSIGN_RANDOM_PORTS - Static variable in class org.apache.hadoop.hbase.LocalHBaseCluster
 
ASSIGN_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
AssignCallable - Class in org.apache.hadoop.hbase.master
A callable object that invokes the corresponding action that needs to be taken for assignment of a region in transition.
AssignCallable(AssignmentManager, HRegionInfo, boolean) - Constructor for class org.apache.hadoop.hbase.master.AssignCallable
 
assignMasterRegions(Collection<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Assign the regions that should be on master regionserver.
AssignmentListener - Interface in org.apache.hadoop.hbase.master
Get notification of assignment events.
AssignmentManager - Class in org.apache.hadoop.hbase.master
Manages and performs region assignment.
AssignmentManager(MasterServices, ServerManager, LoadBalancer, ExecutorService, MetricsMaster, TableLockManager) - Constructor for class org.apache.hadoop.hbase.master.AssignmentManager
Constructs a new assignment manager.
assignmentManager - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
AssignmentManager.ServerHostRegion - Enum in org.apache.hadoop.hbase.master
 
AssignmentManagerStatusTmpl - Class in org.apache.hadoop.hbase.tmpl.master
 
AssignmentManagerStatusTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
 
AssignmentManagerStatusTmpl(String) - Constructor for class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
 
AssignmentManagerStatusTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
 
AssignmentManagerStatusTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.master
 
AssignmentManagerStatusTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
 
AssignmentManagerStatusTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.master
 
AssignmentManagerStatusTmplImpl - Class in org.apache.hadoop.hbase.tmpl.master
 
AssignmentManagerStatusTmplImpl(TemplateManager, AssignmentManagerStatusTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmplImpl
 
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
 
assignmentZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
assignMeta(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Assigns the hbase:meta region or a replica.
assignRegion(RpcController, MasterProtos.AssignRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
assignRegions(MasterProcedureEnv, TableName, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
assignRegions(AssignmentManager, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
Triggers a bulk assignment of the specified regions
asSize() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
asString() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
AsyncConsoleAppender - Class in org.apache.hadoop.hbase
Logger class that buffers before trying to log to the specified console.
AsyncConsoleAppender() - Constructor for class org.apache.hadoop.hbase.AsyncConsoleAppender
 
asyncCreate(ZooKeeperWatcher, String, byte[], AsyncCallback.StringCallback, Object) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Async creates the specified node with the specified data.
asyncCreateNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName, AsyncCallback.StringCallback, Object) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Creates an unassigned node in the OFFLINE state for the specified region.
atLeast(WALKey.Version) - Method in enum org.apache.hadoop.hbase.wal.WALKey.Version
 
ATOMIC_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for AtomicBoolean
ATOMIC_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
atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Atomically increment the column value specified.
atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
atomicIncrement(ByteBuffer, ByteBuffer, byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
AtomicUtils - Class in org.apache.hadoop.hbase.util
Utilities related to atomic operations.
AtomicUtils() - Constructor for class org.apache.hadoop.hbase.util.AtomicUtils
 
attemptingUser - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
attemptToOwnTask(boolean, ZooKeeperWatcher, ServerName, String, ZooKeeperProtos.SplitLogTask.RecoveryMode, int) - Static method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
Try to own the task by transitioning the zk node data from UNASSIGNED to OWNED.
ATTRIBUTE_SEPERATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
Attributes - Interface in org.apache.hadoop.hbase.client
 
Attributes - Class in org.apache.hadoop.hbase.hbtop.terminal
The attributes of text in the terminal.
Attributes() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
Attributes(Attributes) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
Mutation attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
Delete attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
Delete attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
Delete attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
Delete attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
Get attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
Get attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
Get attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
Get attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
Get attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
Get attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
Get attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
Get attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
Get attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
Get attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
Get attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
Mutation attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
Mutation attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
Mutation attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
Mutation attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
Scan attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
Scan attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
Scan attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
Scan attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
Scan attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Scan attributes
attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
ATTRIBUTES_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
ATTRS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
ATTRS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
AUTH_TOKEN_TYPE - Static variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
AUTHENTICATION_FAILURES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHENTICATION_FAILURES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHENTICATION_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
 
authenticationFailure() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authenticationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authenticationFallback() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authenticationFallback() - Method 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
 
authenticationSuccess() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authenticationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
AuthenticationTokenIdentifier - Class in org.apache.hadoop.hbase.security.token
Represents the identity information stored in an HBase authentication token.
AuthenticationTokenIdentifier() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
AuthenticationTokenIdentifier(String) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
AuthenticationTokenIdentifier(String, int, long, long) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
AuthenticationTokenSecretManager - Class in org.apache.hadoop.hbase.security.token
Manages an internal list of secret keys used to sign new authentication tokens as they are generated, and to valid existing tokens used for authentication.
AuthenticationTokenSecretManager(Configuration, ZooKeeperWatcher, String, long, long) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
Create a new secret manager instance for generating keys.
AuthenticationTokenSelector - Class in org.apache.hadoop.hbase.security.token
 
AuthenticationTokenSelector() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
 
AuthFilter - Class in org.apache.hadoop.hbase.rest.filter
 
AuthFilter() - Constructor for class org.apache.hadoop.hbase.rest.filter.AuthFilter
 
authManager - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
AuthMethod - Enum in org.apache.hadoop.hbase.security
Authentication method
AUTHORIZATION - Static variable in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
 
AUTHORIZATION_FAILURES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHORIZATION_FAILURES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHORIZATION_SUCCESSES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHORIZATION_SUCCESSES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authorizationFailure() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authorizationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
Authorizations - Class in org.apache.hadoop.hbase.security.visibility
This class contains visibility labels associated with a Scan/Get deciding which all labeled data current scan/get can access.
Authorizations(String...) - Constructor for class org.apache.hadoop.hbase.security.visibility.Authorizations
 
Authorizations(List<String>) - Constructor for class org.apache.hadoop.hbase.security.visibility.Authorizations
 
authorizations - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
authorizations - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
authorizationSuccess() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authorizationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authorize(UserGroupInformation, RPCProtos.ConnectionHeader, InetAddress) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
Authorize the incoming client connection.
authorize(User, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Authorize a global permission based on ACLs for the given user and the user's groups.
authorize(User, TableName, Cell, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Authorize a user for a given KV.
authorize(User, String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
authorize(User, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
authorize(User, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
authorizeGroup(String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Checks global authorization for a given action for a group, based on the stored permissions.
authorizeGroup(String, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Checks authorization to a given table, column family and column for a group, based on the stored permissions.
authorizeUser(User, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Checks authorization to a given table and column family for a user, based on the stored user permissions.
authorizeUser(User, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
AuthResult - Class in org.apache.hadoop.hbase.security.access
Represents the result of an authorization check for logging and error reporting.
AuthResult(boolean, String, String, User, Permission.Action, TableName, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
 
AuthResult(boolean, String, String, User, Permission.Action, TableName, Map<byte[], ? extends Collection<?>>) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
 
AuthResult(boolean, String, String, User, Permission.Action, String) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
 
AuthResult.Params - Class in org.apache.hadoop.hbase.security.access
 
AuthResult.Params() - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult.Params
 
authTokenSecretMgr - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
AuthUtil - Class in org.apache.hadoop.hbase
Utility methods for helping with security tasks.
available() - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
 
available() - Method in class org.apache.hadoop.hbase.io.LimitInputStream
 
AVERAGE_LOAD_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
AVERAGE_LOAD_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
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
 
AVERAGELOAD_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
avg(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handle for calling the average method for a given cf-cq combination.
avg(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handle for calling the average method for a given cf-cq combination.
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
 
avgKeyLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Average key length read from file info
avgValueLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Average value length read from file info
await() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
 
await() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.CompatibilityLatch
 
await() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Wait until the read point catches up to the write point; i.e.

B

BACK_REFERENCES_DIRECTORY_PREFIX - Static variable in class org.apache.hadoop.hbase.io.FileLink
Define the Back-reference directory name prefix: .links-<hfile>/
BACKOFF_POLICY_CLASS - Static variable in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
 
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
 
backupMasterAddressesZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
BackupMasterStatusTmpl - Class in org.apache.hadoop.hbase.tmpl.master
 
BackupMasterStatusTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
 
BackupMasterStatusTmpl(String) - Constructor for class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
 
BackupMasterStatusTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
 
BackupMasterStatusTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.master
 
BackupMasterStatusTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl.ImplData
 
BackupMasterStatusTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.master
 
BackupMasterStatusTmplImpl - Class in org.apache.hadoop.hbase.tmpl.master
 
BackupMasterStatusTmplImpl(TemplateManager, BackupMasterStatusTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmplImpl
 
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
Seek scanner to the given key first.
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.StoreFileScanner
 
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
 
balance(RegionPlan) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
balance() - Method in class org.apache.hadoop.hbase.master.HMaster
 
balance(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
balance(RpcController, MasterProtos.BalanceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
BALANCE_CLUSTER - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
 
balanceCluster(Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
 
balanceCluster(TableName, Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
 
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<ServerName, List<HRegionInfo>>) - 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.
balanceCluster(TableName, Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
 
balanceCluster(TableName, Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
balanceCluster(Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
Given the cluster state this will try and approach an optimal balance.
balanceCluster(TableName, Map<ServerName, List<HRegionInfo>>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Perform the major balance operation
balanceCluster(Map<ServerName, List<HRegionInfo>>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Perform the major balance operation
balanceCluster(TableName, Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
balanceCluster(Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
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
 
BalancedQueueRpcExecutor(String, int, int, int) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
Deprecated.
BalancedQueueRpcExecutor(String, int, int, int, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
Deprecated.
BalancedQueueRpcExecutor(String, int, int, Class<? extends BlockingQueue>, Object...) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
Deprecated.
BalancedQueueRpcExecutor(String, int, int, Configuration, Abortable, Class<? extends BlockingQueue>, Object...) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
Deprecated.
balanceMasterRegions(Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Balance the regions that should be on master regionserver.
balancer() - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer.
balancer(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer.
balancer() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Invoke the balancer.
balancer(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
BALANCER_STATUS - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
 
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
 
balanceRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Balance regions in the given RegionServer group.
balanceRSGroup(RpcController, RSGroupAdminProtos.BalanceRSGroupRequest, RpcCallback<RSGroupAdminProtos.BalanceRSGroupResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
balanceRSGroup(String) - 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
balancerZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
balanceSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
barrierAcquiredByMember(String) - Method in class org.apache.hadoop.hbase.procedure.Procedure
Call back triggered by an individual member upon successful local barrier acquisition
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
base - Variable in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
Base64 - Class in org.apache.hadoop.hbase.util
Encodes and decodes to and from Base64 notation.
Base64.Base64InputStream - Class in org.apache.hadoop.hbase.util
A Base64.Base64InputStream will read data from another InputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
Base64.Base64InputStream(InputStream, int) - Constructor for class org.apache.hadoop.hbase.util.Base64.Base64InputStream
Constructs a Base64.Base64InputStream in either ENCODE or DECODE mode.
Base64.Base64OutputStream - Class in org.apache.hadoop.hbase.util
A Base64.Base64OutputStream will write data to another OutputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
Base64.Base64OutputStream(OutputStream, int) - Constructor for class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Constructs a Base64.Base64OutputStream in either ENCODE or DECODE mode.
BASE_NAMESPACE_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
 
BASE_WINDOW_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory
 
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
 
BaseCoordinatedStateManager - Class in org.apache.hadoop.hbase.coordination
Base class for CoordinatedStateManager implementations.
BaseCoordinatedStateManager() - Constructor for class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
 
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
 
BaseDecoder.PBIS(InputStream, int) - Constructor for class org.apache.hadoop.hbase.codec.BaseDecoder.PBIS
 
BaseEncoder - Class in org.apache.hadoop.hbase.codec
TODO javadoc
BaseEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.BaseEncoder
 
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
 
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
 
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
BaseLoadBalancer.Cluster - 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.
BaseLoadBalancer.Cluster(Map<ServerName, List<HRegionInfo>>, Map<String, Deque<RegionLoad>>, RegionLocationFinder, RackManager) - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
 
BaseLoadBalancer.Cluster(Collection<HRegionInfo>, Map<ServerName, List<HRegionInfo>>, Map<String, Deque<RegionLoad>>, RegionLocationFinder, RackManager) - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
 
BaseLoadBalancer.Cluster.Action - Class in org.apache.hadoop.hbase.master.balancer
An action to move or swap a region
BaseLoadBalancer.Cluster.Action(BaseLoadBalancer.Cluster.Action.Type) - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.Action
 
BaseLoadBalancer.Cluster.Action.Type - Enum in org.apache.hadoop.hbase.master.balancer
 
BaseLoadBalancer.Cluster.AssignRegionAction - Class in org.apache.hadoop.hbase.master.balancer
 
BaseLoadBalancer.Cluster.AssignRegionAction(int, int) - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.AssignRegionAction
 
BaseLoadBalancer.Cluster.MoveRegionAction - Class in org.apache.hadoop.hbase.master.balancer
 
BaseLoadBalancer.Cluster.MoveRegionAction(int, int, int) - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.MoveRegionAction
 
BaseLoadBalancer.Cluster.SwapRegionsAction - Class in org.apache.hadoop.hbase.master.balancer
 
BaseLoadBalancer.Cluster.SwapRegionsAction(int, int, int, int) - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.SwapRegionsAction
 
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
 
BaseMasterAndRegionObserver - Class in org.apache.hadoop.hbase.coprocessor
 
BaseMasterAndRegionObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
BaseMasterObserver - Class in org.apache.hadoop.hbase.coprocessor
 
BaseMasterObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
BaseRegionObserver - Class in org.apache.hadoop.hbase.coprocessor
An abstract class that implements RegionObserver.
BaseRegionObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
BaseRegionServerObserver - Class in org.apache.hadoop.hbase.coprocessor
An abstract class that implements RegionServerObserver.
BaseRegionServerObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
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
 
BaseSource - Interface in org.apache.hadoop.hbase.metrics
BaseSource for dynamic metrics to announce to Metrics2.
BaseSourceImpl - Class in org.apache.hadoop.hbase.metrics
Hadoop 2 implementation of BaseSource (using metrics2 framework).
BaseSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
BaseWALEntryFilter - Class in org.apache.hadoop.hbase.replication
A base class WALEntryFilter implementations.
BaseWALEntryFilter() - Constructor for class org.apache.hadoop.hbase.replication.BaseWALEntryFilter
 
BaseWALObserver - Class in org.apache.hadoop.hbase.coprocessor
An abstract class that implements WALObserver.
BaseWALObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
 
baseZNode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
baseZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
Batch - Class in org.apache.hadoop.hbase.client.coprocessor
A collection of interfaces and utilities used for interacting with custom RPC interfaces exposed by Coprocessors.
Batch() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.Batch
 
batch(List<? extends Row>, Object[], int) - Method in class org.apache.hadoop.hbase.client.HTable
 
batch(List<? extends Row>, Object[]) - Method in class org.apache.hadoop.hbase.client.HTable
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations The ordering of execution of the actions is not defined.
batch(List<? extends Row>) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use HTable.batch(List, Object[]) instead.
batch(List<? extends Row>, Object[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
batch(List<? extends Row>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use HTableWrapper.batch(List, Object[]) instead.
batch(List<? extends Row>, Object[]) - Method in interface org.apache.hadoop.hbase.client.Table
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations The ordering of execution of the actions is not defined.
batch(List<? extends Row>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use Table.batch(List, Object[]) instead.
batch - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
batch(TableName, Collection<List<Row>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
Do the changes and handle the pool
batch(List<? extends Row>, Object[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batch(List<? extends Row>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
Batch.Call<T,R> - Interface in org.apache.hadoop.hbase.client.coprocessor
Defines a unit of work to be executed.
Batch.Callback<R> - Interface in org.apache.hadoop.hbase.client.coprocessor
Defines a generic callback to be triggered for each Batch.Call.call(Object) result.
BATCH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
BATCH_GET_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
BATCH_MUTATE_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
Same as Table.batch(List, Object[]), but with a callback.
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use HTable.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead.
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use HTableWrapper.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead.
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Same as Table.batch(List, Object[]), but with a callback.
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use Table.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead.
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in class org.apache.hadoop.hbase.client.HTable
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchMutate(Mutation[], long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchMutate(Mutation[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchMutate(Mutation[], long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Perform a batch of mutations.
BatchMutation - Class in org.apache.hadoop.hbase.thrift.generated
 
BatchMutation() - Constructor for class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
BatchMutation(ByteBuffer, List<Mutation>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
BatchMutation(BatchMutation) - Constructor for class org.apache.hadoop.hbase.thrift.generated.BatchMutation
Performs a deep copy on other.
BatchMutation._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
batchReplay(WALSplitter.MutationReplay[], long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchReplay(WALSplitter.MutationReplay[], long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Replay a batch of mutations.
BatchScanResultCache - Class in org.apache.hadoop.hbase.client
A scan result cache for batched scan, i.e, scan.getBatch() > 0 && !scan.getAllowPartialResults().
BatchScanResultCache(List<Result>, int) - Constructor for class org.apache.hadoop.hbase.client.BatchScanResultCache
 
batchSize - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
 
batchSize - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
bcn - Variable in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
bcv - Variable in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
beforeExecute() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
Called before compaction is executed by CompactSplitThread; for use by coproc subclasses.
beforeExecute(Thread, Runnable) - Method in class org.apache.hadoop.hbase.thrift.THBaseThreadPoolExecutor
 
beforeFirst - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
beforeProcess(EventHandler) - Method in interface org.apache.hadoop.hbase.executor.EventHandler.EventHandlerListener
Called before any event is processed
beforeReplay(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called when the procedure is loaded for replay.
beforeWaitOnSafePoint() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
begin() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
begin(Runnable) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Start a write transaction.
beginOp() - Method in class org.apache.hadoop.hbase.util.DrainBarrier
Tries to start an operation.
beginPersistentOutput() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
enables output as a single, persistent list.
BigDecimalColumnInterpreter - Class in org.apache.hadoop.hbase.client.coprocessor
ColumnInterpreter for doing Aggregation's with BigDecimal columns.
BigDecimalColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
BinaryComparator - Class in org.apache.hadoop.hbase.filter
A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
BinaryComparator(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryComparator
Constructor
BinaryPrefixComparator - Class in org.apache.hadoop.hbase.filter
A comparator which compares against a specified byte array, but only compares up to the length of this byte array.
BinaryPrefixComparator(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
Constructor
binaryPrefixType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
BinaryPrefixType byte array
binarySearch(Cell[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
 
binarySearch(Cell[], byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Searches for the latest value for the specified column.
binarySearch(byte[][], byte[], int, int, RawComparator<?>) - Static method in class org.apache.hadoop.hbase.util.Bytes
Binary search for keys in indexes.
binarySearch(byte[][], Cell, RawComparator<Cell>) - Static method in class org.apache.hadoop.hbase.util.Bytes
Binary search for keys in indexes.
binaryType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
BinaryType byte array
bind(ServerSocket, InetSocketAddress, int) - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
A convenience method to bind to a given address and report better exceptions if the address is not a valid host.
BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
bindAddress - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
BitComparator - Class in org.apache.hadoop.hbase.filter
A bit comparator which performs the specified bitwise operation on each of the bytes with the specified byte array.
BitComparator(byte[], BitComparator.BitwiseOp) - Constructor for class org.apache.hadoop.hbase.filter.BitComparator
Constructor
BitComparator.BitwiseOp - Enum in org.apache.hadoop.hbase.filter
Bit operators.
bitOperator - Variable in class org.apache.hadoop.hbase.filter.BitComparator
 
blacklistedRegions - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
blobVarEncodedLength(int) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Calculate the expected BlobVar encoded length based on unencoded length.
block - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
block - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
fields
block - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
fields
block - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.MvccVersionDecoder
 
block - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.TimestampDecoder
 
block - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
block - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
BLOCK_CACHE_BLOOM_CHUNK_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_BLOOM_CHUNK_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DATA_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DATA_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DELETE_FAMILY_BLOOM_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DELETE_FAMILY_BLOOM_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_ENCODED_DATA_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_ENCODED_DATA_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EVICTION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EVICTION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EXPRESS_HIT_PERCENT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EXPRESS_HIT_PERCENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FAILED_INSERTION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FAILED_INSERTION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FILE_INFO_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FILE_INFO_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FREE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FREE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_GENERAL_BLOOM_META_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_GENERAL_BLOOM_META_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_PERCENT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_PERCENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_INTERMEDIATE_INDEX_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_INTERMEDIATE_INDEX_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_LEAF_INDEX_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_LEAF_INDEX_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_META_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_META_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_EVICTION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_EVICTION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_HIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_ROOT_INDEX_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_ROOT_INDEX_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_SIZE_MAX_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
BLOCK_CACHE_SIZE_MIN_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
BLOCK_CACHE_TRAILER_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_TRAILER_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_COUNT_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_COUNT_PRIMARY_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
blockBuffer - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Key for the BLOCKCACHE attribute.
BlockCache - Interface in org.apache.hadoop.hbase.io.hfile
Block cache interface.
BLOCKCACHE_BLOCKSIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
The target block size used by blockcache instances.
blockCacheEnabled - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
BlockCacheKey - Class in org.apache.hadoop.hbase.io.hfile
Cache Key for use with implementations of BlockCache
BlockCacheKey(String, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
Construct a new BlockCacheKey
BlockCacheKey(String, long, boolean, BlockType) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
BlockCacheTmpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
BlockCacheTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
 
BlockCacheTmpl(String) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
 
BlockCacheTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
 
BlockCacheTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
BlockCacheTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.ImplData
 
BlockCacheTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.regionserver
 
BlockCacheTmplImpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
BlockCacheTmplImpl(TemplateManager, BlockCacheTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmplImpl
 
BlockCacheUtil - Class in org.apache.hadoop.hbase.io.hfile
Utilty for aggregating counts in CachedBlocks and toString/toJSON CachedBlocks and BlockCaches.
BlockCacheUtil() - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
 
BlockCacheUtil.CachedBlocksByFile - Class in org.apache.hadoop.hbase.io.hfile
Use one of these to keep a running account of cached blocks by file.
BlockCacheViewTmpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
BlockCacheViewTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
 
BlockCacheViewTmpl(String) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
 
BlockCacheViewTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
 
BlockCacheViewTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
BlockCacheViewTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
 
BlockCacheViewTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.regionserver
 
BlockCacheViewTmplImpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
BlockCacheViewTmplImpl(TemplateManager, BlockCacheViewTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmplImpl
 
BLOCKED_REQUESTS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCKED_REQUESTS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
blockEncoder - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
The data block encoding which will be used.
blockFetches - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
BLOCKING_STOREFILES_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
BlockingRpcCallback<R> - Class in org.apache.hadoop.hbase.ipc
Simple RpcCallback implementation providing a Future-like BlockingRpcCallback.get() method, which will block util the instance's BlockingRpcCallback.run(Object) method has been called.
BlockingRpcCallback() - Constructor for class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
 
BlockingRpcClient - Class in org.apache.hadoop.hbase.ipc
Does RPC against a cluster.
BlockingRpcClient(Configuration, String, SocketAddress, MetricsConnection) - Constructor for class org.apache.hadoop.hbase.ipc.BlockingRpcClient
Construct an IPC client for the cluster clusterId with the default SocketFactory This method is called with reflection by the RpcClientFactory to create an instance
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
fields
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
fields
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
fields
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.MvccVersionDecoder
 
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.TimestampDecoder
 
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
 
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
BlockPriority - Enum in org.apache.hadoop.hbase.io.hfile
 
blockSeek(Cell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
Within a loaded block, seek looking for the last key that is smaller than (or equal to?) the key we are interested in.
blockSeek(Cell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
Within a loaded block, seek looking for the last key that is smaller than (or equal to?) the key we are interested in.
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Size of storefile/hfile 'blocks'.
BlockType - Enum in org.apache.hadoop.hbase.io.hfile
Various types of HFile blocks.
BlockType.BlockCategory - Enum in org.apache.hadoop.hbase.io.hfile
 
blockUntilAvailable(ZooKeeperWatcher, long, Configuration) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Wait until the primary meta region is available.
blockUntilAvailable(ZooKeeperWatcher, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Wait until the meta region is available and is not in transition.
blockUntilAvailable(ZooKeeperWatcher, int, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Wait until the meta region is available and is not in transition.
blockUntilAvailable(ZooKeeperWatcher, String, long) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
blockUntilAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Gets the data of the node, blocking until the node is available.
blockUntilAvailable(long, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Gets the data of the node, blocking until the node is available or the specified timeout has elapsed.
blockUntilNoRIT(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Blocks until there are no node in regions in transition.
blockUntilRIT(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Blocks until there is at least one node in regions in transition.
BlockWithScanInfo - Class in org.apache.hadoop.hbase.io.hfile
BlockWithScanInfo is wrapper class for HFileBlock with other attributes.
BlockWithScanInfo(HFileBlock, Cell) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
 
blockWritten(long, int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Called after an inline block has been written so that we can add an entry referring to that block to the parent-level index.
blockWritten(long, int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
Called after a block has been written, and its offset, raw size, and compressed size have been determined.
blockWritten(long, int, int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
 
bloom - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Bloom bits
BLOOM_FILTER_DATA_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Meta data block name for bloom filter bits.
BLOOM_FILTER_TYPE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Bloom filter Type in FileInfo
BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
BloomFilter - Interface in org.apache.hadoop.hbase.util
Defines the general behavior of a bloom filter.
BloomFilterBase - Interface in org.apache.hadoop.hbase.util
Common methods Bloom filter methods required at read and write time.
BloomFilterFactory - Class in org.apache.hadoop.hbase.util
Handles Bloom filter initialization based on configuration and serialized metadata in the reader and writer of StoreFile.
bloomFilterNbHashes - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
bloomFilterType - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
bloomFilterType - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
bloomFilterVectorSize - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
BloomFilterWriter - Interface in org.apache.hadoop.hbase.util
Specifies methods needed to add elements to a Bloom filter and serialize the resulting Bloom filter as a sequence of bytes.
BloomType - Enum in org.apache.hadoop.hbase.regionserver
 
BOGUS_SERVER_NAME - Static variable in interface org.apache.hadoop.hbase.master.LoadBalancer
 
boundaries - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
BoundedArrayQueue<E> - Class in org.apache.hadoop.hbase.util
A bounded non-thread safe implementation of Queue.
BoundedArrayQueue(int) - Constructor for class org.apache.hadoop.hbase.util.BoundedArrayQueue
 
BoundedByteBufferPool - Class in org.apache.hadoop.hbase.io
Like Hadoops' ByteBufferPool only you do not specify desired size when getting a ByteBuffer.
BoundedByteBufferPool(int, int, int, boolean) - Constructor for class org.apache.hadoop.hbase.io.BoundedByteBufferPool
 
BoundedCompletionService<V> - Class in org.apache.hadoop.hbase.util
A completion service, close to the one available in the JDK 1.7 However, this ones keeps the list of the future, and allows to cancel them all.
BoundedCompletionService(Executor, int) - Constructor for class org.apache.hadoop.hbase.util.BoundedCompletionService
 
BoundedGroupingStrategy - Class in org.apache.hadoop.hbase.wal
A WAL grouping strategy that limits the number of wal groups to "hbase.wal.regiongrouping.numgroups".
BoundedGroupingStrategy() - Constructor for class org.apache.hadoop.hbase.wal.BoundedGroupingStrategy
 
BoundedPriorityBlockingQueue<E> - Class in org.apache.hadoop.hbase.util
A generic bounded blocking Priority-Queue.
BoundedPriorityBlockingQueue(int, Comparator<? super E>) - Constructor for class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
Creates a PriorityQueue with the specified capacity that orders its elements according to the specified comparator.
BROWSER_USER_AGENT_PARAM - Static variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
 
BUCKET_CACHE_BUCKETS_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
A comma-delimited array of values for use as bucket sizes.
BUCKET_CACHE_COMBINED_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
If the bucket cache is used in league with the lru on-heap block cache (meta blocks such as indices and blooms are kept in the lru blockcache and the data blocks in the bucket cache).
BUCKET_CACHE_IOENGINE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Current ioengine options in include: heap, offheap and file:PATH (where PATH is the path to the file that will host the file-based cache.
BUCKET_CACHE_PERSISTENT_PATH_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
If the chosen ioengine can persist its state across restarts, the path to the file to persist to.
BUCKET_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
When using bucket cache, this is a float that EITHER represents a percentage of total heap memory size to give to the cache (if < 1.0) OR, it is the capacity in megabytes of the cache.
BUCKET_CACHE_WRITER_QUEUE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
BUCKET_CACHE_WRITER_THREADS_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
BucketAllocator - Class in org.apache.hadoop.hbase.io.hfile.bucket
This class is used to allocate a block with specified size and free the block when evicting.
BucketAllocator.Bucket - Class in org.apache.hadoop.hbase.io.hfile.bucket
 
BucketAllocator.Bucket(long) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
BucketAllocatorException - Exception in org.apache.hadoop.hbase.io.hfile.bucket
Thrown by BucketAllocator
BucketCache - Class in org.apache.hadoop.hbase.io.hfile.bucket
BucketCache uses BucketAllocator to allocate/free blocks, and uses BucketCache#ramCache and BucketCache#backingMap in order to determine if a given element is in the cache.
BucketCache(String, long, int, int[], int, int, String) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
BucketCache(String, long, int, int[], int, int, String, int, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
BucketCacheStats - Class in org.apache.hadoop.hbase.io.hfile.bucket
Class that implements cache metrics for bucket cache.
bucketIndex() - Method in exception org.apache.hadoop.hbase.io.hfile.bucket.CacheFullException
 
bucketRsBatch(HTable, List<Row>) - Static method in class org.apache.hadoop.hbase.client.HTableUtil
Deprecated.
Processes a List of Rows (Put, Delete) and writes them to an HTable instance in RegionServer buckets via the htable.batch method.
bucketRsPut(HTable, List<Put>) - Static method in class org.apache.hadoop.hbase.client.HTableUtil
Deprecated.
Processes a List of Puts and writes them to an HTable instance in RegionServer buckets via the htable.put method.
buf - Variable in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
BufferedMutator - Interface in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table similar to Table but meant for batched, asynchronous puts.
BufferedMutator.ExceptionListener - Interface in org.apache.hadoop.hbase.client
Listens for asynchronous exceptions on a BufferedMutator.
BufferedMutatorExample - Class in org.apache.hadoop.hbase.client.example
An example of using the BufferedMutator interface.
BufferedMutatorExample() - Constructor for class org.apache.hadoop.hbase.client.example.BufferedMutatorExample
 
BufferedMutatorImpl - Class in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table similar to HTable but meant for batched, potentially asynchronous puts.
BufferedMutatorParams - Class in org.apache.hadoop.hbase.client
Parameters for instantiating a BufferedMutator.
BufferedMutatorParams(TableName) - Constructor for class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
bufferForColumnName() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
bufferForEndKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
bufferForEndKey() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
bufferForFamily() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
bufferForFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
bufferForFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
bufferForFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
bufferForFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
bufferForFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
bufferForFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
bufferForFilterString() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
bufferForFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
bufferForFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
bufferForName() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
bufferForName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
bufferForQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
bufferForQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
bufferForQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
bufferForQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
bufferForQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
bufferForQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
bufferForServerName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
bufferForStartAndPrefix() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
bufferForStartKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
bufferForStartKey() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
bufferForStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
bufferForStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
bufferForStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
bufferForStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
bufferForStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
bufferForStartRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
bufferForStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
bufferForStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
bufferForStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
bufferForStopRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
bufferForTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
bufferForTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
bufferForTags() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
bufferForValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
bufferForValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
bufferForValue() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
bufferForValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
bufferForValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
bufferForValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
bufferForValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
bufferOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
 
build() - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
build() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
build(Configuration, TableName, String, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create an HFileLink instance from table/region/family/hfile location
build() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
build() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
 
build() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
Create a store file writer.
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
buildActionResult(Throwable) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Wrap a throwable to an action result.
buildActionResult(ClientProtos.Result) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Wrap a throwable to an action result.
buildAddColumnRequest(TableName, HColumnDescriptor, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer AddColumnRequest
buildAssignRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer AssignRegionRequest
buildBalanceRequest(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer BalanceRequest
buildBulkLoadHFileRequest(List<Pair<byte[], String>>, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Deprecated.
use buildBulkLoadHFileRequest(final List> familyPaths, final byte[] regionName, boolean assignSeqNum, List clusterIds)
buildBulkLoadHFileRequest(List<Pair<byte[], String>>, byte[], boolean, List<String>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer bulk load request
buildCatalogScanRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for running a catalog scan
buildCleanerChoreRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for running cleaner chore
buildClearDeadServersRequest(List<ServerName>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
 
buildCloseRegionRequest(ServerName, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a CloseRegionRequest for a given region name
buildCloseRegionRequest(ServerName, byte[], int, ServerName, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
 
buildCloseRegionRequest(ServerName, String, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a CloseRegionRequest for a given encoded region name
buildCompactRegionRequest(byte[], boolean, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a CompactRegionRequest for a given region name
buildCondition(byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer Condition
buildCreateTableRequest(HTableDescriptor, byte[][], long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer CreateTableRequest
buildDeleteColumnRequest(TableName, byte[], long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer DeleteColumnRequest
buildDeleteTableRequest(TableName, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer DeleteTableRequest
buildDependencyClasspath(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Returns a classpath string built from the content of the "tmpjars" value in conf.
buildDisableTableRequest(TableName, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer DisableTableRequest
buildDispatchMergingRegionsRequest(byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
 
buildEnableCatalogJanitorRequest(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for enabling/disabling the catalog janitor
buildEnableCatalogJanitorResponse(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the catalog scan request
buildEnableTableRequest(TableName, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer EnableTableRequest
builder - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
builder() - Static method in class org.apache.hadoop.hbase.hbtop.Record
 
builderNode - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
fields
buildException(Throwable) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
 
buildFilter(String) - Static method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
buildFilter(String) - Static method in class org.apache.hadoop.hbase.rest.ResultGenerator
 
buildFilterFromModel(ScannerModel) - Static method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
buildFlushRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer FlushRegionRequest for a given region name
buildFlushRegionRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer FlushRegionRequest for a given region name
buildFromHFileLinkPattern(Configuration, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
 
buildFromHFileLinkPattern(Path, Path, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
 
buildGetClusterStatusRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetClusterStatusRequest
buildGetLastFlushedSequenceIdRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for querying the master the last flushed sequence Id for a region
buildGetLastFlushedSequenceIdResponse(ClusterStatusProtos.RegionStoreSequenceIds) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the last flushed sequence Id request
buildGetOnlineRegionRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetOnlineRegionRequest
buildGetOnlineRegionResponse(List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
A utility to build a GetOnlineRegionResponse.
buildGetRegionInfoRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetRegionInfoRequest for a given region name
buildGetRegionInfoRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetRegionInfoRequest for a given region name
buildGetRequest(byte[], Get) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetRequest for a client Get
buildGetRowOrBeforeRequest(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new protocol buffer GetRequest to get a row, all columns in a family.
buildGetSchemaAlterStatusRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetSchemaAlterStatusRequest
buildGetServerInfoRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new GetServerInfoRequest
buildGetServerInfoResponse(ServerName, int) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
A utility to build a GetServerInfoResponse.
buildGetStoreFileRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetStoreFileRequest for a given region name
buildGetTableDescriptorsRequest(List<TableName>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest
buildGetTableDescriptorsRequest(Pattern, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest
buildGetTableDescriptorsRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest for a single table
buildGetTableNamesRequest(Pattern, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableNamesRequest
buildGetUserPermissionsResponse(List<UserPermission>) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Converts the permissions list into a protocol buffer GetUserPermissionsResponse
buildGrantRequest(String, boolean, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to grant user permissions.
buildGrantRequest(String, TableName, byte[], byte[], boolean, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to grant user permissions.
buildGrantRequest(String, String, boolean, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to grant user permissions.
buildIncrementRequest(byte[], byte[], byte[], byte[], long, Durability, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a client increment
buildIsBalancerEnabledRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsBalancerEnabledRequest
buildIsCatalogJanitorEnabledRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for querying the master whether the catalog janitor is enabled
buildIsCleanerChoreEnabledRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for querying the master whether the cleaner chore is enabled
buildIsMasterRunningRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsMasterRunningRequest
buildIsNormalizerEnabledRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsNormalizerEnabledRequest
buildIsSplitOrMergeEnabledRequest(Admin.MasterSwitchType) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsSplitOrMergeEnabledRequest
buildJMXServiceURL(int, int) - Static method in class org.apache.hadoop.hbase.JMXListener
 
buildMergeRegionsRequest(byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a MergeRegionsRequest for the given regions
buildModelFromPut(Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildModifyColumnRequest(TableName, HColumnDescriptor, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ModifyColumnRequest
buildModifyTableRequest(TableName, HTableDescriptor, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer ModifyTableRequest
buildMoveRegionRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MoveRegionRequest
buildMultiRowSpec(byte[][], int) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, Put) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a conditioned put
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, Delete) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a conditioned delete
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, RowMutations) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for conditioned row mutations
buildMutateRequest(byte[], Put) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a put
buildMutateRequest(byte[], Append, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for an append
buildMutateRequest(byte[], Increment, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a client increment
buildMutateRequest(byte[], Delete) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a delete
buildNoDataRegionAction(byte[], RowMutations, List<CellScannable>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MultiRequest for row mutations that does not hold data.
buildNoDataRegionAction(byte[], List<Action<R>>, List<CellScannable>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer multirequest with NO data for a list of actions (data is carried otherwise than via protobuf).
buildNormalizeRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer NormalizeRequest
buildOfflineRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer OfflineRegionRequest
buildOpenRegionRequest(ServerName, List<Triple<HRegionInfo, Integer, List<ServerName>>>, Boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer OpenRegionRequest to open a list of regions
buildOpenRegionRequest(ServerName, HRegionInfo, int, List<ServerName>, Boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer OpenRegionRequest for a given region
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
buildRegionAction(byte[], RowMutations) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MultiRequest for row mutations.
buildRegionAction(byte[], List<Action<R>>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer multi request for a list of actions.
buildRegionSpecifier(HBaseProtos.RegionSpecifier.RegionSpecifierType, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Convert a byte array to a protocol buffer RegionSpecifier
buildReplicateWALEntryRequest(WAL.Entry[]) - Static method in class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
Create a new ReplicateWALEntryRequest from a list of WAL entries
buildReplicateWALEntryRequest(WAL.Entry[], byte[], String, Path, Path) - Static method in class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
Create a new ReplicateWALEntryRequest from a list of HLog entries
buildReplicationLoad(List<MetricsSource>, MetricsSink) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
buildReplicationLoad
buildResultFromModel(CellSetModel) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildRevokeRequest(String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to revoke user permissions.
buildRevokeRequest(String, TableName, byte[], byte[], AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to revoke user permissions.
buildRevokeRequest(String, String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to revoke user permissions.
buildRollWALWriterRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new RollWALWriterRequest
buildRowSpec(byte[], Map, long, long, int) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildRunCatalogScanResponse(int) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the catalog scan request
buildRunCleanerChoreResponse(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the cleaner chore request
buildScanRequest(byte[], Scan, int, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a client Scan
buildScanRequest(long, int, boolean, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildScanRequest(long, int, boolean, long, boolean, boolean, int) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildServiceCall(byte[], Descriptors.MethodDescriptor, Message) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
Returns a service call instance for the given coprocessor request.
buildSetBalancerRunningRequest(boolean, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer SetBalancerRunningRequest
buildSetCleanerChoreRunningRequest(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for enabling/disabling the cleaner chore
buildSetNormalizerRunningRequest(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer SetNormalizerRunningRequest
buildSetQuotaRequestProto(QuotaSettings) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
Deprecated.
Removed in HBase 2.0+ as a part of removing protobuf from our API
buildSetSplitOrMergeEnabledRequest(boolean, boolean, Admin.MasterSwitchType...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer SetSplitOrMergeEnabledRequest
buildSplitRegionRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a SplitRegionRequest for a given region name
buildStopServerRequest(String) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new StopServerRequest
buildString(String...) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
 
buildSubprocedure(String) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
If in a running state, creates the specified subprocedure to flush table regions.
buildSubprocedure(String, byte[]) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager.FlushTableSubprocedureBuilder
 
buildSubprocedure(String, byte[]) - Method in interface org.apache.hadoop.hbase.procedure.SubprocedureFactory
Build Subprocedure when requested.
buildSubprocedure(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
If in a running state, creates the specified subprocedure for handling an online snapshot.
buildSubprocedure(String, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedureBuilder
 
buildTruncateTableRequest(TableName, boolean, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer TruncateTableRequest
buildUnassignRegionRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer UnassignRegionRequest
buildUpdateFavoredNodesRequest(List<Pair<HRegionInfo, List<ServerName>>>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings
buildWALHeader(Configuration, WALProtos.WALHeader.Builder) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
buildWALHeader(Configuration, WALProtos.WALHeader.Builder) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogWriter
 
buildWarmupRegionRequest(HRegionInfo) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a WarmupRegionRequest for a given region name
buildZKQuorumServerString(String[], String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
Build the ZK quorum server string with "server:clientport" list, separated by ','
BULK_ASSIGN_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
BULK_LOAD - Static variable in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
BULK_OUTPUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
BULK_OUTPUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
bulkAssign() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
 
bulkAssign(boolean) - Method in class org.apache.hadoop.hbase.master.BulkAssigner
Run the bulk assign.
BulkAssigner - Class in org.apache.hadoop.hbase.master
Base class used bulk assigning and unassigning regions.
BulkAssigner(Server) - Constructor for class org.apache.hadoop.hbase.master.BulkAssigner
 
BulkDeleteEndpoint - Class in org.apache.hadoop.hbase.coprocessor.example
Defines a protocol to delete data in bulk based on a scan.
BulkDeleteEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
 
BulkDeleteProtos - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteRequest - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf type hbase.pb.BulkDeleteRequest
BulkDeleteProtos.BulkDeleteRequest.Builder - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf type hbase.pb.BulkDeleteRequest
BulkDeleteProtos.BulkDeleteRequest.DeleteType - Enum in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf enum hbase.pb.BulkDeleteRequest.DeleteType
BulkDeleteProtos.BulkDeleteRequestOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteResponse - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf type hbase.pb.BulkDeleteResponse
BulkDeleteProtos.BulkDeleteResponse.Builder - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf type hbase.pb.BulkDeleteResponse
BulkDeleteProtos.BulkDeleteResponseOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteService - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf service hbase.pb.BulkDeleteService
BulkDeleteProtos.BulkDeleteService() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
 
BulkDeleteProtos.BulkDeleteService.BlockingInterface - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteService.Interface - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteService.Stub - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
BULKLOAD_MAX_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum time to retry for a failed bulk load request
BULKLOAD_TASK_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Meta key set when store file is a result of a bulk load
BULKLOAD_TIME_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
 
BulkLoadCellFilter - Class in org.apache.hadoop.hbase.replication
 
BulkLoadCellFilter() - Constructor for class org.apache.hadoop.hbase.replication.BulkLoadCellFilter
 
bulkLoadHFile(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Deprecated.
use bulkLoadHFile(final ClientService.BlockingInterface client, final List> familyPaths, final byte[] regionName, boolean assignSeqNum, List clusterIds) instead.
bulkLoadHFile(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean, List<String>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to bulk load a list of HFiles using client protocol.
bulkLoadHFile(byte[], String, Path) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
bulkLoadHFile(StoreFileInfo) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
bulkLoadHFile(RpcController, ClientProtos.BulkLoadHFileRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Atomically bulk load several HFiles into an open region
bulkLoadHFile(byte[], String, Path) - Method in interface org.apache.hadoop.hbase.regionserver.Store
This method should only be called from Region.
bulkLoadHFile(StoreFileInfo) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
bulkLoadHFiles(List<Pair<byte[], String>>, Token<?>, String, byte[]) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
Deprecated. 
bulkLoadHFiles(List<Pair<byte[], String>>, Token<?>, String, byte[], List<String>) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
bulkLoadHFiles(Collection<Pair<byte[], String>>, boolean, Region.BulkLoadListener, List<String>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
bulkLoadHFiles(Collection<Pair<byte[], String>>, boolean, Region.BulkLoadListener) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Deprecated.
bulkLoadHFiles(Collection<Pair<byte[], String>>, boolean, Region.BulkLoadListener, List<String>) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Attempts to atomically load a group of hfiles.
bulkLoadHFiles(Collection<Pair<byte[], String>>, boolean, Region.BulkLoadListener) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Deprecated.
Do not use, see HBASE-22380
BulkLoadObserver - Interface in org.apache.hadoop.hbase.coprocessor
Coprocessors implement this interface to observe and mediate bulk load operations.
bulkLoadPhase(Table, Connection, ExecutorService, Deque<LoadIncrementalHFiles.LoadQueueItem>, Multimap<ByteBuffer, LoadIncrementalHFiles.LoadQueueItem>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
This takes the LQI's grouped by likely regions and attempts to bulk load them.
BulkReOpen - Class in org.apache.hadoop.hbase.master
Performs bulk reopen of the list of regions provided to it.
BulkReOpen(Server, Map<ServerName, List<HRegionInfo>>, AssignmentManager) - Constructor for class org.apache.hadoop.hbase.master.BulkReOpen
 
bulkReOpen() - Method in class org.apache.hadoop.hbase.master.BulkReOpen
 
BusyRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
This class represents a split policy which makes the split decision based on how busy a region is.
BusyRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
 
bypass() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
Call to indicate that the current coprocessor's return value should be used in place of the normal HBase obtained value.
bypassGlobals(String, boolean) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Set the "bypass global settings" for the specified user
BYTE_7_RIGHT_BITS_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVIntTool
 
BYTE_7_RIGHT_BITS_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVLongTool
 
BYTE_ARRAY_BASE_OFFSET - Static variable in class org.apache.hadoop.hbase.util.UnsafeAccess
The offset to the first element in a byte array.
BYTE_BUFFER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ByteBuffer
BYTE_BUFFER_HEAP_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
BYTE_LEFT_BIT_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVIntTool
 
BYTE_LEFT_BIT_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVLongTool
 
byteAppender - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
fields
ByteArrayComparable - Class in org.apache.hadoop.hbase.filter
Base class for byte array comparators
ByteArrayComparable(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ByteArrayComparable
Constructor.
ByteArrayOutputStream - Class in org.apache.hadoop.hbase.io
Our own implementation of ByteArrayOutputStream where all methods are NOT synchronized and supports writing ByteBuffer directly to it.
ByteArrayOutputStream() - Constructor for class org.apache.hadoop.hbase.io.ByteArrayOutputStream
 
ByteArrayOutputStream(int) - Constructor for class org.apache.hadoop.hbase.io.ByteArrayOutputStream
 
ByteBloomFilter - Class in org.apache.hadoop.hbase.util
Implements a Bloom filter, as defined by Bloom in 1970.
ByteBloomFilter(DataInput) - Constructor for class org.apache.hadoop.hbase.util.ByteBloomFilter
Loads bloom filter meta data from file input.
ByteBloomFilter(int, double, int, int) - Constructor for class org.apache.hadoop.hbase.util.ByteBloomFilter
Determines & initializes bloom filter meta data from user config.
ByteBufferArray - Class in org.apache.hadoop.hbase.util
This class manages an array of ByteBuffers with a default size 4MB.
ByteBufferArray(long, boolean) - Constructor for class org.apache.hadoop.hbase.util.ByteBufferArray
We allocate a number of byte buffers as the capacity.
ByteBufferInputStream - Class in org.apache.hadoop.hbase.io
Not thread safe!
ByteBufferInputStream(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferInputStream
 
ByteBufferIOEngine - Class in org.apache.hadoop.hbase.io.hfile.bucket
IO engine that stores data in memory using an array of ByteBuffers ByteBufferArray
ByteBufferIOEngine(long, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
Construct the ByteBufferIOEngine with the given capacity
ByteBufferOutputStream - Class in org.apache.hadoop.hbase.io
Not thread safe!
ByteBufferOutputStream(int) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteBufferOutputStream(int, boolean) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteBufferOutputStream(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteBufferUtils - Class in org.apache.hadoop.hbase.util
Utility functions for working with byte buffers, such as reading/writing variable-length long numbers.
ByteRange - Interface in org.apache.hadoop.hbase.util
Lightweight, reusable class for specifying ranges of byte[]'s.
ByteRangeHashSet - Class in org.apache.hadoop.hbase.util.byterange.impl
This is probably the best implementation of ByteRangeSet at the moment, though a HashMap produces garbage when adding a new element to it.
ByteRangeHashSet() - Constructor for class org.apache.hadoop.hbase.util.byterange.impl.ByteRangeHashSet
constructors
ByteRangeHashSet(List<ByteRange>) - Constructor for class org.apache.hadoop.hbase.util.byterange.impl.ByteRangeHashSet
 
ByteRangeSet - Class in org.apache.hadoop.hbase.util.byterange
Performance oriented class for de-duping and storing arbitrary byte[]'s arriving in non-sorted order.
ByteRangeSet() - Constructor for class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
construct
ByteRangeTreeSet - Class in org.apache.hadoop.hbase.util.byterange.impl
Not currently used in production, but here as a benchmark comparison against ByteRangeHashSet.
ByteRangeTreeSet() - Constructor for class org.apache.hadoop.hbase.util.byterange.impl.ByteRangeTreeSet
constructors
ByteRangeTreeSet(List<ByteRange>) - Constructor for class org.apache.hadoop.hbase.util.byterange.impl.ByteRangeTreeSet
 
ByteRangeUtils - Class in org.apache.hadoop.hbase.util
Utility methods for working with ByteRange.
ByteRangeUtils() - Constructor for class org.apache.hadoop.hbase.util.ByteRangeUtils
 
bytes - Variable in class org.apache.hadoop.hbase.KeyValue
 
bytes - Variable in class org.apache.hadoop.hbase.util.AbstractByteRange
The array containing the bytes in this range.
Bytes - Class in org.apache.hadoop.hbase.util
Utility class that handles byte arrays, conversions to/from other types, comparisons, hash code generation, manufacturing keys for HashMaps or HashSets, etc.
Bytes() - Constructor for class org.apache.hadoop.hbase.util.Bytes
Create a zero-size sequence.
Bytes(byte[]) - Constructor for class org.apache.hadoop.hbase.util.Bytes
Create a Bytes using the byte array as the initial value.
Bytes(Bytes) - Constructor for class org.apache.hadoop.hbase.util.Bytes
Set the new Bytes to the contents of the passed ibw.
Bytes(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.Bytes
Set the value to a given byte range
Bytes.ByteArrayComparator - Class in org.apache.hadoop.hbase.util
Byte array comparator class.
Bytes.ByteArrayComparator() - Constructor for class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
Constructor
Bytes.RowEndKeyComparator - Class in org.apache.hadoop.hbase.util
A Bytes.ByteArrayComparator that treats the empty array as the largest value.
Bytes.RowEndKeyComparator() - Constructor for class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
 
BYTES_COMPARATOR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Pass this to TreeMaps where byte [] are keys.
BYTES_COMPARATOR - Static variable in class org.apache.hadoop.hbase.util.RegionSplitCalculator
 
BYTES_IN_REMOTE_RESULTS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
BYTES_IN_RESULTS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.HConstants
The name of the configuration parameter that specifies the number of bytes in a newly created checksum chunk.
BYTES_RAWCOMPARATOR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Use comparing byte arrays, byte-by-byte
byteSize - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Bytes (B) in the array.
ByteSlot - Class in org.apache.hadoop.hbase.procedure2.util
Similar to the ByteArrayOutputStream, with the exception that we can prepend an header.
ByteSlot() - Constructor for class org.apache.hadoop.hbase.procedure2.util.ByteSlot
 
bytesPerDelta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
bytesPerIndex - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
bytesToVint(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
ByteStringer - Class in org.apache.hadoop.hbase.util
Hack to workaround HBASE-1304 issue that keeps bubbling up when a mapreduce context.
byteStringUncompressor - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 

C

cache - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
CACHE_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to cache data blocks on write.
CACHE_BLOOM_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to cache compound bloom filter blocks on write.
CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
CACHE_DATA_BLOCKS_COMPRESSED_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to cache data blocks in compressed and/or encrypted format.
CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Key for cache data into L1 if cache is set up with more than one tier.
CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
CACHE_FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
CACHE_INDEX_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to cache leaf and intermediate-level index blocks on write.
CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
Cacheable - Interface in org.apache.hadoop.hbase.io.hfile
Cacheable is an interface that allows for an object to be cached.
CacheableDeserializer<T extends Cacheable> - Interface in org.apache.hadoop.hbase.io.hfile
Interface for a deserializer.
CacheableDeserializerIdManager - Class in org.apache.hadoop.hbase.io.hfile
This class is used to manage the identifiers for CacheableDeserializer
CacheableDeserializerIdManager() - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
 
cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Add block to cache.
cacheBlock(BlockCacheKey, Cacheable) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Add block to cache (defaults to not in-memory).
cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
Cache the block with the specified name and buffer.
cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
Cache the block with the specified name and buffer.
cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
 
cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Cache the block with the specified name and buffer.
cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Cache the block with the specified name and buffer.
cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
cacheBlocks - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
cacheBlocks - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
cacheBlocks - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
 
cacheBlocks - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
CACHEBLOCKS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
cacheBlockWithWait(BlockCacheKey, Cacheable, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
Cache the block to ramCache
cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Block cache configuration.
cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Cache configuration for caching data on write.
cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
CacheConfig - Class in org.apache.hadoop.hbase.io.hfile
Stores all of the cache objects and configuration for a single HFile.
CacheConfig(Configuration, HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
Create a cache configuration using the specified configuration object and family descriptor.
CacheConfig(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
Create a cache configuration using the specified configuration object and defaults for family level settings.
CacheConfig(CacheConfig) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
Constructs a cache configuration copied from the specified configuration.
cacheConfig - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
CachedBlock - Interface in org.apache.hadoop.hbase.io.hfile
 
CachedEntryQueue - Class in org.apache.hadoop.hbase.io.hfile.bucket
A memory-bound queue that will grow until an element brings total size larger than maxSize.
CachedEntryQueue(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
 
cacheFlusher - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
CacheFullException - Exception in org.apache.hadoop.hbase.io.hfile.bucket
Thrown by BucketAllocator.allocateBlock(int) when cache is full for the requested size
cacheLocation(TableName, RegionLocations) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
cacheLocation(TableName, ServerName, HRegionLocation) - Method in class org.apache.hadoop.hbase.client.MetaCache
Put a newly discovered HRegionLocation into the cache.
cacheLocation(TableName, RegionLocations) - Method in class org.apache.hadoop.hbase.client.MetaCache
Put a newly discovered HRegionLocation into the cache.
cacheSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
Total size of all elements in this queue.
CacheStats - Class in org.apache.hadoop.hbase.io.hfile
Class that implements cache metrics.
CacheStats(String) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheStats
 
CacheStats(String, int) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheStats
 
caching - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
caching - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
 
caching - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
CACHING_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
calcCoverage() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
Generates a coverage multimap from split key to Regions that start with the split key.
calcIndexKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
calcIndexKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.RawBytesComparator
 
calculateAutoBalancedSplits(List<InputSplit>, long) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Calculates the number of MapReduce input splits for the map tasks.
calculateChecksum(String) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
 
calculateChecksum(String) - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.PersistentIOEngine
Using an encryption algorithm to calculate a checksum, the default encryption algorithm is MD5
calculateMutationSize(Mutation) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
calculateNumMetaBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
operate on each field
calculateOffsetsAndLengths() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
methods
calculateOverhead(long, long, int) - Static method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
calculateRebalancedSplits(List<InputSplit>, JobContext, long) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Deprecated. 
calculateResultSize(Result) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
calculateResultSize(List<Result>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
calculateTheClosestNextRowKeyForPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientUtil
When scanning for a prefix the scan should stop immediately after the the last row that has the specified prefix.
calculateWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
calculateWidthOverrideOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
call(T) - Method in interface org.apache.hadoop.hbase.client.coprocessor.Batch.Call
 
call(int) - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
call() - Method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.ReadExampleCallable
 
call() - Method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.SingleWriteExampleCallable
 
call() - Method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.WriteExampleCallable
 
call(int) - Method in class org.apache.hadoop.hbase.client.FlushRegionCallable
 
call(int) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
Computes a result, or throws an exception if unable to do so.
call(int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
Algo: - we put the query into the execution pool.
call(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler, long, int) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
This is a server side method, which is invoked over RPC.
call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
Deprecated.
As of release 1.3, this will be removed in HBase 3.0
call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler, long, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
 
call() - Method in class org.apache.hadoop.hbase.master.AssignCallable
 
call() - Method in class org.apache.hadoop.hbase.master.UnAssignCallable
 
call() - Method in class org.apache.hadoop.hbase.procedure.Procedure
This call is the main execution thread of the barriered procedure.
call() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
Execute the Subprocedure Subprocedure.acquireBarrier() and Subprocedure.insideBarrier() methods while keeping some state for other threads to access.
call() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure.RegionSnapshotTask
 
call() - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint.Replicator
 
call(Class<T>, T, String, Class[], Object[]) - Static method in class org.apache.hadoop.hbase.util.Methods
 
CALL_QUEUE_CODEL_DEFAULT_INTERVAL - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_CODEL_DEFAULT_LIFO_THRESHOLD - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_CODEL_DEFAULT_TARGET_DELAY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_CODEL_INTERVAL - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_CODEL_LIFO_THRESHOLD - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_CODEL_TARGET_DELAY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_HANDLER_FACTOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_LEN_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
CALL_QUEUE_READ_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
CALL_QUEUE_SCAN_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
CALL_QUEUE_TYPE_CODEL_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
The default, 'fifo', has the least friction but is dumb.
CALL_QUEUE_TYPE_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_TYPE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_TYPE_DEADLINE_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_TYPE_FIFO_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
callable - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
 
callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
CallCancelledException - Exception in org.apache.hadoop.hbase.ipc
Client side call cancelled.
CallCancelledException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallCancelledException
 
CallDroppedException - Exception in org.apache.hadoop.hbase
Returned to the clients when their request was discarded due to server being overloaded.
CallDroppedException() - Constructor for exception org.apache.hadoop.hbase.CallDroppedException
 
CallDroppedException(String) - Constructor for exception org.apache.hadoop.hbase.CallDroppedException
 
caller - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
CallerDisconnectedException - Exception in org.apache.hadoop.hbase.ipc
Exception indicating that the remote host making this IPC lost its IPC connection.
CallerDisconnectedException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallerDisconnectedException
 
callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.MasterCoprocessorRpcChannel
 
callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
 
callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.RegionServerCoprocessorRpcChannel
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
CallQueue - Class in org.apache.hadoop.hbase.thrift
A BlockingQueue reports waiting time in queue and queue length to ThriftMetrics.
CallQueue(BlockingQueue<CallQueue.Call>, ThriftMetrics) - Constructor for class org.apache.hadoop.hbase.thrift.CallQueue
 
CallQueue.Call - Class in org.apache.hadoop.hbase.thrift
 
callQueueSize - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
This is a running count of the size of all outstanding calls by size.
CallQueueTooBigException - Exception in org.apache.hadoop.hbase
 
CallQueueTooBigException() - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
 
CallQueueTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
 
callQueueTooBigException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
callQueueTooBigException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
CallRunner - Class in org.apache.hadoop.hbase.ipc
The request processing logic, which is usually executed in thread pools provided by an RpcScheduler.
CallTimeoutException - Exception in org.apache.hadoop.hbase.ipc
Client-side call timeout
CallTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallTimeoutException
 
callWithoutRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCaller
Call the server once only.
callWithRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCaller
Retries if invocation fails.
Canary - Interface in org.apache.hadoop.hbase.tool
 
Canary.Factory - Class in org.apache.hadoop.hbase.tool
 
Canary.Factory() - Constructor for class org.apache.hadoop.hbase.tool.Canary.Factory
 
CanaryTool - Class in org.apache.hadoop.hbase.tool
HBase Canary Tool for "canary monitoring" of a running HBase cluster.
CanaryTool() - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool
 
CanaryTool(ExecutorService) - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool
 
CanaryTool.Monitor - Class in org.apache.hadoop.hbase.tool
A Monitor super-class can be extended by users
CanaryTool.Monitor(Connection, String[], boolean, CanaryTool.Sink, ExecutorService, boolean, long) - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
CanaryTool.RegionServerStdOutSink - Class in org.apache.hadoop.hbase.tool
By RegionServer, for 'regionserver' mode.
CanaryTool.RegionServerStdOutSink() - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerStdOutSink
 
CanaryTool.RegionStdOutSink - Class in org.apache.hadoop.hbase.tool
By Region, for 'region' mode.
CanaryTool.RegionStdOutSink() - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
 
CanaryTool.RegionTaskResult - Class in org.apache.hadoop.hbase.tool
Canary region mode-specific data structure which stores information about each region to be scanned
CanaryTool.RegionTaskResult(HRegionInfo, TableName, ServerName) - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
CanaryTool.Sink - Interface in org.apache.hadoop.hbase.tool
Sink interface used by the canary to output information
CanaryTool.StdOutSink - Class in org.apache.hadoop.hbase.tool
Simple implementation of canary sink that allows plotting to a file or standard output.
CanaryTool.StdOutSink() - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
 
CanaryTool.ZookeeperStdOutSink - Class in org.apache.hadoop.hbase.tool
Output for 'zookeeper' mode.
CanaryTool.ZookeeperStdOutSink() - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.ZookeeperStdOutSink
 
cancel(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
cancel() - Method in class org.apache.hadoop.hbase.client.PayloadCarryingServerCallable
 
cancel() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCaller
 
cancel(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
 
cancel(boolean) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
cancel(boolean) - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
 
cancel(String) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
 
cancel(String) - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
 
cancel(String) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
cancel(String) - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
Actively cancel a running snapshot.
cancel(String, Throwable) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
Method to cancel the Subprocedure by injecting an exception from and external source.
cancel() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
Cancels the compaction progress, setting things to 0.
cancel() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
cancel(boolean) - Method in class org.apache.hadoop.hbase.ScheduledChore
 
CancelableProgressable - Interface in org.apache.hadoop.hbase.util
Similar interface as Progressable but returns a boolean to support canceling the operation.
cancelAll() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
cancelAll(boolean) - Method in class org.apache.hadoop.hbase.util.BoundedCompletionService
 
cancelChore(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
 
cancelChore(ScheduledChore, boolean) - Method in class org.apache.hadoop.hbase.ChoreService
 
cancelConnections(ServerName) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Interrupt the connections to the given ip:port server.
cancelConnections(ServerName) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
Interrupt the connections to the given server.
cancelLease(String) - Method in class org.apache.hadoop.hbase.regionserver.Leases
Client explicitly cancels a lease.
cancelRequestedCompaction(CompactionContext) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
cancelRequestedCompaction(CompactionContext) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
cancelTimer() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
cancelTimer() - Method in class org.apache.hadoop.hbase.hbtop.screen.Screen
 
canCreateBaseZNode() - Method in class org.apache.hadoop.hbase.master.HMaster
 
canCreateBaseZNode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
canExecute() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
Is there at least one resource available to allow execution?
canExecute(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
Are there enough available resources to allow execution?
canGrow(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
canMerge(ProcedureStoreTracker.BitSetNode) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
canQueue() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
 
canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
 
canReplicateToSameCluster() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Whether or not, the replication endpoint can replicate to it's source cluster with the same UUID
canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
canSplit() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
canSplit() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
canUpdateTableDescriptor() - Method in class org.apache.hadoop.hbase.master.HMaster
 
canUpdateTableDescriptor() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
carryForwardTags(Cell) - Static method in class org.apache.hadoop.hbase.Tag
 
carryForwardTags(List<Tag>, Cell) - Static method in class org.apache.hadoop.hbase.Tag
 
castToCellType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
castToCellType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
castToCellType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
castToCellType(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
The response message comes as type S.
castToReturnType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
castToReturnType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
castToReturnType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
castToReturnType(T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
provides casting opportunity between the data types.
CATALOG_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
The catalog family
CATALOG_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The catalog family as a string
CatalogJanitor - Class in org.apache.hadoop.hbase.master
A janitor for the catalog tables.
catalogJanitorEnabled - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
cConnection - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
cConnection - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
ceiling(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
ceilingEntry(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
ceilingKey(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
Cell - Interface in org.apache.hadoop.hbase
The unit of storage in HBase consisting of the following fields:
Cell - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
Represents a single text cell of the terminal.
Cell() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
cell - Variable in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
CELL_SKIPLIST_SET - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for CellSkipListSet
CELL_TTL_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
CELL_VISIBILITY_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
cellBlockBuilder - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
CellCodec - Class in org.apache.hadoop.hbase.codec
Basic Cell codec that just writes out all the individual elements of a Cell.
CellCodec() - Constructor for class org.apache.hadoop.hbase.codec.CellCodec
 
CellCodecWithTags - Class in org.apache.hadoop.hbase.codec
Basic Cell codec that just writes out all the individual elements of a Cell including the tags.
CellCodecWithTags() - Constructor for class org.apache.hadoop.hbase.codec.CellCodecWithTags
 
CellComparator - Class in org.apache.hadoop.hbase
Compare two HBase cells.
CellComparator() - Constructor for class org.apache.hadoop.hbase.CellComparator
 
CellComparator.RowComparator - Class in org.apache.hadoop.hbase
Counter part for the KeyValue.RowOnlyComparator
CellComparator.RowComparator() - Constructor for class org.apache.hadoop.hbase.CellComparator.RowComparator
 
CellCounter - Class in org.apache.hadoop.hbase.mapreduce
A job with a a map and reduce phase to count cells in a table.
CellCounter() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCounter
 
CellCreator - Class in org.apache.hadoop.hbase.mapreduce
Facade to create Cells for HFileOutputFormat.
CellCreator(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCreator
 
cellDecoder - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
cellEncoder - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
cellFromHBase(Cell) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell object.
cellFromHBase(Cell[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell array.
CellMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
CellMessage.Cell - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.Cell
CellMessage.Cell.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.Cell
CellMessage.CellOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
CellModel - Class in org.apache.hadoop.hbase.rest.model
Representation of a cell.
CellModel() - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
Default constructor
CellModel(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
Constructor
CellModel(byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
Constructor
CellModel(Cell) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
Constructor from KeyValue
CellModel(byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
Constructor
CellModel(byte[], byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
Constructor
CellOutputStream - Interface in org.apache.hadoop.hbase.io
Accepts a stream of Cells.
CellScannable - Interface in org.apache.hadoop.hbase
Implementer can return a CellScanner over its Cell content.
cellScanner() - Method in interface org.apache.hadoop.hbase.CellScannable
 
CellScanner - Interface in org.apache.hadoop.hbase
An interface for iterating through a sequence of cells.
cellScanner() - Method in class org.apache.hadoop.hbase.client.Mutation
 
cellScanner() - Method in class org.apache.hadoop.hbase.client.Result
 
cellScanner() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
cellScanner() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
cellScanner - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
CellScannerButNoCodecException - Exception in org.apache.hadoop.hbase.ipc
Thrown if a cellscanner but no codec to encode it with.
CellScannerButNoCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.CellScannerButNoCodecException
 
CellScannerPosition - Enum in org.apache.hadoop.hbase.codec.prefixtree.scanner
An indicator of the state of the scanner after an operation such as nextCell() or positionAt(..).
CellSearcher - Interface in org.apache.hadoop.hbase.codec.prefixtree.scanner
Methods for seeking to a random Cell inside a sorted collection of cells.
CellSetMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
CellSetMessage.CellSet - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.CellSet
CellSetMessage.CellSet.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.CellSet
CellSetMessage.CellSet.Row - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row
CellSetMessage.CellSet.Row.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row
CellSetMessage.CellSet.RowOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
CellSetMessage.CellSetOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
CellSetModel - Class in org.apache.hadoop.hbase.rest.model
Representation of a grouping of cells.
CellSetModel() - Constructor for class org.apache.hadoop.hbase.rest.model.CellSetModel
Constructor
CellSetModel(List<RowModel>) - Constructor for class org.apache.hadoop.hbase.rest.model.CellSetModel
 
CellSkipListSet - Class in org.apache.hadoop.hbase.regionserver
A Set of Cells implemented on top of a ConcurrentSkipListMap.
cellsPerHeartbeatCheck - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
CellTypeEncoder - Class in org.apache.hadoop.hbase.codec.prefixtree.encode.other
Detect if every KV has the same KeyValue.Type, in which case we don't need to store it for each KV.
CellTypeEncoder() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
 
cellTypeEncoder - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
CellUtil - Class in org.apache.hadoop.hbase
Utility methods helpful slinging Cell instances.
CellUtil() - Constructor for class org.apache.hadoop.hbase.CellUtil
 
CellVisibility - Class in org.apache.hadoop.hbase.security.visibility
This contains a visibility expression which can be associated with a cell.
CellVisibility(String) - Constructor for class org.apache.hadoop.hbase.security.visibility.CellVisibility
 
cellVisibility - Variable in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
cellVisibility - Variable in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
cellVisibility - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
cellVisibilityExpr - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
CF_ATTRIBUTE_EARLY_OUT - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Configuration or CF schema option for early termination of access checks if table or CF permissions grant access.
CF_RENAME_PROP - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
CFNAME - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
ChainWALEntryFilter - Class in org.apache.hadoop.hbase.replication
A WALEntryFilter which contains multiple filters and applies them in chain order
ChainWALEntryFilter(WALEntryFilter...) - Constructor for class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
 
ChainWALEntryFilter(List<WALEntryFilter>) - Constructor for class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
 
chance - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
ChangedReadersObserver - Interface in org.apache.hadoop.hbase.regionserver
If set of MapFile.Readers in Store change, implementors are notified.
channel - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.SaslUnwrapHandler
 
channelRead(ReadableByteChannel, ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.security.SaslUnwrapHandler
 
channelWrite(GatheringByteChannel, BufferChain) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
character(Character) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
check(Put) - Method in interface org.apache.hadoop.hbase.constraint.Constraint
Check a Put to ensure it is valid for the table.
CHECK_AND_DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CHECK_AND_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CHECK_AUTHS_FOR_MUTATION - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
CHECK_MUTATE_FAILED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CHECK_MUTATE_FAILED_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CHECK_MUTATE_PASSED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CHECK_MUTATE_PASSED_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
checkAccess(UserGroupInformation, FileStatus, FsAction) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Throw an exception if an action is not permitted by a user on a file.
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
checkAndGetReversed(List<Filter>, boolean) - Static method in class org.apache.hadoop.hbase.filter.FilterListBase
 
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Mutation, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Mutation, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Atomically checks if a row/family/qualifier value matches the expected val If it does, it performs the row mutations.
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
checkAndMutate(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TCompareOp, ByteBuffer, TRowMutations, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
checkAndMutate(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TCompareOp, ByteBuffer, TRowMutations, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
checkAndMutate(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TCompareOp, ByteBuffer, TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
checkAndMutate(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TCompareOp, ByteBuffer, TRowMutations) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndMutate(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TCompareOp, ByteBuffer, TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Atomically checks if a row/family/qualifier value matches the expected value.
checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
checkAndRemoveTableState(TableName, ZooKeeperProtos.Table.State, boolean) - Method in interface org.apache.hadoop.hbase.TableStateManager
If the table is found in the given state the in-memory state is removed.
checkAndRemoveTableState(TableName, ZooKeeperProtos.Table.State, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
If the table is found in the given state the in-memory state is removed.
checkAndRowMutate(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, RowMutations, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
checkAndRowMutate(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, RowMutations, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Atomically checks if a row/family/qualifier value matches the expected val If it does, it performs the row mutations.
checkAndSetZNodeAcls() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
On master start, we check the znode ACLs under the root directory and set the ACLs properly if needed.
checkAndUpdateNamespaceRegionQuota(TableName, int) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
checkBlockBoundary() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
At a block boundary, write all the inline blocks and opens new block.
checkClosingState(HRegionInfo, CloseRegionCoordination.CloseRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.CloseRegionCoordination
Called before actual region closing to check that we can do close operation on this region.
checkClosingState(HRegionInfo, CloseRegionCoordination.CloseRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination
In ZK-based version we're checking for bad znode state, e.g.
checkClosingState(ZooKeeperWatcher, HRegionInfo, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
 
checkClusterIdExists(FileSystem, Path, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Checks that a cluster ID file exists in the HBase root directory
checkColFamDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
Check all files in a column family dir.
checkColumn(byte[], int, int, byte) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
Checks if the column is present in the list of requested columns by returning the match code instance.
checkColumn(byte[], int, int, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
Checks if the column is present in the list of requested columns by returning the match code instance.
checkColumn(byte[], int, int, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
Checks if the column is present in the list of requested columns by returning the match code instance.
checkDeleted(DeleteTracker, Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
checkDfsSafeMode(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Check whether dfs is in safemode.
checkDifferencesWithOldPlan(Map<TableName, Integer>, Map<String, Map<String, Float>>, FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
Compares two plans and check whether the locality dropped or increased (prints the information as a string) also prints the baseline locality
checkExists(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Check if the specified node exists.
checkFailed() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
Throws an IOException back out if one is currently stored.
checkFamilies(Collection<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
checkFamilies(Collection<byte[]>) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Check the collection of families for validity.
checkFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
Checks to see if the file system is still accessible.
checkFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Checks to see if the file system is still accessible.
checkFileSystemAvailable(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Checks to see if the specified file system is available
checkFlushed() - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
 
checkFlushed() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
checkForAnd(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'AND'
checkForClusterFreeMemoryLimit(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
Checks whether we have enough heap memory left out after portion for Memstore and Block cache.
checkFormatVersion(int) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Checks the given HFile format version, and throws an exception if invalid.
checkForOr(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'OR'
checkForSkip(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'SKIP'
checkForWhile(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'WHILE'
checkHBaseAvailable(Configuration) - Static method in class org.apache.hadoop.hbase.client.HBaseAdmin
Check to see if HBase is running.
checkHFile(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
Checks a path to see if it is a valid hfile.
checkIfBaseNodeAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Checks if the baseznode set as per the property 'zookeeper.znode.parent' exists.
checkIfRegionServerIsRemote() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
compare the local machine hostname with region server's hostname to decide if hbase client connects to a remote region server
checkIfShouldMoveSystemRegionAsync() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Start a new thread to check if there are region servers whose versions are higher than others.
checkIfShouldMoveSystemRegionAsync() - Method in class org.apache.hadoop.hbase.master.HMaster
 
checkIfShouldMoveSystemRegionAsync() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
checkIn(PrefixTreeArraySearcher) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.ArraySearcherPool
 
checkIn(CellSearcher) - Static method in class org.apache.hadoop.hbase.codec.prefixtree.decode.DecoderFactory
 
checkIn(PrefixTreeEncoder) - Static method in class org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderFactory
 
checkIn(PrefixTreeEncoder) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderPool
 
checkIn(PrefixTreeEncoder) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderPoolImpl
 
checkIOException(IOException) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
Examine passed IOException.
checkKey(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Checks that the given Cell's key does not violate the key order.
checkKeyLen(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
checkKeyValueLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
Check key and value lengths are wholesome.
checkLen(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
checkLockExists(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
checkLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
Schedule a log roll if needed.
checkMinFilesCriteria(ArrayList<StoreFile>, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
 
checkNamespaceTableAndRegionQuota(TableName, int) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
checkOnlyMemStore() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
StoreFiles will not be scanned.
checkOnlyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
MemStore will not be scanned.
checkOOME(Throwable) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRPCErrorHandler
Take actions on the event of an OutOfMemoryError.
checkOOME(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
checkOpen() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Called to verify that this server is up and running.
checkOut(ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.ArraySearcherPool
 
checkOut(ByteBuffer, boolean) - Static method in class org.apache.hadoop.hbase.codec.prefixtree.decode.DecoderFactory
 
checkOut(OutputStream, boolean) - Static method in class org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderFactory
 
checkOut(OutputStream, boolean) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderPool
 
checkOut(OutputStream, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderPoolImpl
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Checks if the output table exists and is enabled.
checkPermission(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest, RpcCallback<AccessControlProtos.CheckPermissionsResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
checkQuota(int, int, int) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
checkQuota(int, int, int) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Checks if it is possible to execute the specified operation.
checkQuota(long, long, long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
Checks if it is possible to execute the specified operation.
checkQuota(Region, OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
Check the quota for the current (rpc-context) user.
checkQuota(Region, List<ClientProtos.Action>) - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
Check the quota for the current (rpc-context) user.
checkQuota(long, long, long, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
 
checkQuotaToCreateTable(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
Check quota to create table.
checkQuotaToSplitRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
 
checkQuotaToUpdateRegion(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
Check and update region count quota for an existing table.
checkReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
checkReadsEnabled() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
checkRegionBoundaries() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
checkRegionChain(TableIntegrityErrorHandler) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
Check the region chain (from META) of this table.
checkRegionDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
Check all column families in a region dir.
checkRegions(String[]) - Method in interface org.apache.hadoop.hbase.tool.Canary
Run Canary in Region mode.
checkRegions(String[]) - Method in class org.apache.hadoop.hbase.tool.CanaryTool
 
checkRegionServers(String[]) - Method in interface org.apache.hadoop.hbase.tool.Canary
Runs Canary in Region server mode.
checkRegionServers(String[]) - Method in class org.apache.hadoop.hbase.tool.CanaryTool
 
checkReseek(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
checkRow(Cell) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
 
checkScanOrder(Cell, Cell, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
Check whether scan as expected order
checkShortCircuitReadBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Check if short circuit read buffer size is set and if not, set it to hbase value.
checkSnapshotSupport() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Throws an exception if snapshot operations (take a snapshot, restore, clone) are not supported.
checkSplit() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Return the splitpoint.
checkState(int) - Method in interface org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
 
CHECKSUM_FAILURES_DESC - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
 
CHECKSUM_FAILURES_KEY - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
 
CHECKSUM_TYPE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
The name of the configuration parameter that specifies the name of an algorithm that is used to compute checksums for newly created blocks.
ChecksumFactory - Class in org.apache.hadoop.hbase.util
Utility class that is used to generate a Checksum object.
ChecksumFactory() - Constructor for class org.apache.hadoop.hbase.util.ChecksumFactory
 
checksumOk() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
Report that checksum was ok, so we may ponder going back to HBase checksum.
ChecksumType - Enum in org.apache.hadoop.hbase.util
Checksum types.
ChecksumUtil - Class in org.apache.hadoop.hbase.io.hfile
Utility methods to compute and validate checksums.
ChecksumUtil() - Constructor for class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
 
checkTableLocks() - Method in class org.apache.hadoop.hbase.util.hbck.TableLockChecker
 
checkTableModifiable(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
 
checkTableModifiable(TableName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Check table is modifiable; i.e.
checkTableModifiable(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterDDLOperationHelper
Check whether a table is modifiable - exists and either offline or online with config set
checkTables(Collection<Path>) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
Check the specified table dirs for bad hfiles.
checkTasks() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
tells Coordination that it should check for new tasks
checkTasks() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
checkTaskStillAvailable(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Check that the task is still there
checkTaskStillAvailable(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
checkThrowable(Throwable) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
Examine passed Throwable.
checkTimestamps(Map<byte[], List<Cell>>, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
checkTimestamps(Map<byte[], List<Cell>>, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Check the collection of families for valid timestamps
checkType(TMutation._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
checkUnDeletedQueues() - Method in class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
 
checkUpdateNumberOfCompleteRowsAndCache(Result) - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
 
checkValue(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Checks the given value for validity.
checkVersion(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Verifies current version of file system
checkVersion(FileSystem, Path, boolean, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Verifies current version of file system
checkVersions(byte[], int, int, long, byte, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
Keeps track of the number of versions for the columns asked for.
checkVersions(byte[], int, int, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
 
checkVersions(byte[], int, int, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
Keeps track of the number of versions for the columns asked for.
checkZk() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
Try to create a Zookeeper connection.
checkZooKeeper() - Method in interface org.apache.hadoop.hbase.tool.Canary
Runs Canary in Zookeeper mode.
checkZooKeeper() - Method in class org.apache.hadoop.hbase.tool.CanaryTool
 
children - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
childrenCountDown() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called by the ProcedureExecutor to notify that one of the sub-procedures has completed.
childZNode - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
 
chooseSinks() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
Refresh the list of sinks.
chore() - Method in class org.apache.hadoop.hbase.HealthCheckChore
 
chore() - Method in class org.apache.hadoop.hbase.master.balancer.BalancerChore
 
chore() - Method in class org.apache.hadoop.hbase.master.balancer.ClusterStatusChore
 
chore() - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
 
chore() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
 
chore() - Method in class org.apache.hadoop.hbase.master.cleaner.ReplicationZKLockCleanerChore
 
chore() - Method in class org.apache.hadoop.hbase.master.cleaner.ReplicationZKNodeCleanerChore
 
chore() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
 
chore() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerChore
 
chore() - Method in class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
 
chore() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionsCleaner
 
chore() - Method in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
 
chore() - Method in class org.apache.hadoop.hbase.ScheduledChore
The task to execute on each scheduled execution of the Chore
CHORE_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
If it is an integer and >= 1, it would be the size; if 0.0 < size <= 1.0, size would be available processors * size.
choreForTesting() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
ChoreService - Class in org.apache.hadoop.hbase
ChoreService is a service that can be used to schedule instances of ScheduledChore to run periodically while sharing threads.
ChoreService(String) - Constructor for class org.apache.hadoop.hbase.ChoreService
 
ChoreService(String, boolean) - Constructor for class org.apache.hadoop.hbase.ChoreService
 
ChoreService(String, int, boolean) - Constructor for class org.apache.hadoop.hbase.ChoreService
 
Cipher - Class in org.apache.hadoop.hbase.io.crypto
A common interface for a cryptographic algorithm.
Cipher(CipherProvider) - Constructor for class org.apache.hadoop.hbase.io.crypto.Cipher
 
CIPHER_AES - Static variable in class org.apache.hadoop.hbase.HConstants
Default cipher for encryption
CIPHER_MODE_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
CIPHER_PROVIDER_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
CipherProvider - Interface in org.apache.hadoop.hbase.io.crypto
An CipherProvider contributes support for various cryptographic Ciphers.
claimQueue(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Take ownership for the queue identified by queueId and belongs to a dead region server.
claimQueue(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
Classes - Class in org.apache.hadoop.hbase.util
Utilities for class manipulation.
Classes() - Constructor for class org.apache.hadoop.hbase.util.Classes
 
classifyExs(List<Throwable>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
ClassLoaderBase - Class in org.apache.hadoop.hbase.util
Base class loader that defines couple shared constants used by sub-classes.
ClassLoaderBase(ClassLoader) - Constructor for class org.apache.hadoop.hbase.util.ClassLoaderBase
Creates a DynamicClassLoader that can load classes dynamically from jar files under a specific folder.
ClassSize - Class in org.apache.hadoop.hbase.util
Class for determining the "size" of a class, an attempt to calculate the actual bytes that an object of this class will occupy in memory The core of this class is taken from the Derby project
ClassSize() - Constructor for class org.apache.hadoop.hbase.util.ClassSize
 
clean(HRegionInfo) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
This method is used during rollback
clean(HRegionInfo) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
clean the split transaction
clean(HRegionInfo) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
 
clean(HRegionInfo) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
 
cleanAllPreviousInstances(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
 
CleanerChore<T extends FileCleanerDelegate> - Class in org.apache.hadoop.hbase.master.cleaner
Abstract Cleaner that uses a chain of delegates to clean a directory of files
CleanerChore(String, int, Stoppable, Configuration, FileSystem, Path, String, DirScanPool) - Constructor for class org.apache.hadoop.hbase.master.cleaner.CleanerChore
 
CleanerChore(String, int, Stoppable, Configuration, FileSystem, Path, String, DirScanPool, Map<String, Object>) - Constructor for class org.apache.hadoop.hbase.master.cleaner.CleanerChore
 
cleanersChain - Variable in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
 
cleanMergeQualifier(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
Checks if the specified region has merge qualifiers, if so, try to clean them
cleanMovedRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Remove the expired entries from the moved regions list.
cleanOldLogs(String, String, boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Cleans a log file and all older files from ZK.
cleanOutCrashedServerReferences(ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Clean out crashed server removing any assignments.
cleanPreviousInstance(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
A dead server that comes back alive has a different start code.
cleanup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, ImmutableBytesWritable>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
 
cleanup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
 
cleanup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
 
cleanup() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
 
cleanup() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
cleanup() - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
 
cleanup() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
 
cleanup() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
Explicitly mark this status as able to be cleaned up, even though it might not be complete.
cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
Cancel threads if they haven't finished.
cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
Users should override this method.
cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
 
cleanup(Exception) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
Cancel threads if they haven't finished.
cleanup() - Method in class org.apache.hadoop.hbase.ScheduledChore
Override to run cleanup tasks when the Chore encounters an error and must stop running
cleanupBulkLoad(String) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
cleanupBulkLoad(RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.CleanupBulkLoadResponse>) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
 
cleanUpHFileRefs(String, List<String>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
 
cleanupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
cleanupRSGroupForTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
clear() - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
 
clear() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
These methods are unsupported, and no code using CompoundConfiguration depend upon them.
clear() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.hbtop.Record
 
clear() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
 
clear() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
clear() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
 
clear() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
clear() - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
 
clear() - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
Flushes the dictionary, empties all values.
clear() - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
 
clear() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
clear() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
clear() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
 
clear() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
Removes all the MetricRegisties.
clear() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
Removes all of the elements from this collection.
clear() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
 
clear() - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
 
clear() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
clear() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Clears all entries from the map.
clear() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
clear() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
clear() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
clear() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Removes all metrics about this Source.
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
clear() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
clear() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
clear() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
clear() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
clear() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
clear() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
clear() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
clear() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
clear() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
clear() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
clear() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
clear() - Method in class org.apache.hadoop.hbase.util.SortedList
 
clear(Configuration) - Static method in class org.apache.hadoop.hbase.ZNodeClearer
Delete the master znode if its content (ServerName string) is the same as the one in the znode file.
clear() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
Resets the estimator, clearing out all previously inserted items
clearAll() - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
 
clearArchive() - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
 
clearAttrs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
clearAttrs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
clearAuths(byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
clearAuths(Configuration, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
clearAuths(Connection, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
Removes given labels from user's globally authorized list of labels.
clearAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
clearAuths(byte[], List<byte[]>) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
Removes given labels from user's globally authorized list of labels.
clearAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional double averageLoad = 5;
clearBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 batch = 4;
clearCache() - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete all cached entries.
clearCache(ServerName) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete all cached entries of a server.
clearCache(TableName) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete all cached entries of a table.
clearCache(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete a cached location, no matter what it is.
clearCache(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete a cached location with specific replicaId.
clearCache(TableName, byte[], ServerName) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete a cached location for a table, row and server
clearCache(HRegionInfo) - Method in class org.apache.hadoop.hbase.client.MetaCache
Deletes the cached location of the region if necessary, based on some error from source.
clearCache(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.MetaCache
 
clearCache() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Clears the cache.
clearCache() - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
 
clearCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bool cacheBlocks = 11;
clearCaches(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Clear any caches that pertain to server name sn.
clearCaches(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
clearCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 caching = 9;
clearChildZNodes() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
clearColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes column = 2;
clearColumnBuffer() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
 
clearColumns() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated bytes columns = 3;
clearColumns() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
clearCompactedFiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Clears all the compacted files and returns them.
clearCompactedFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
clearCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string compression = 5;
clearCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
required int64 count = 1 [default = 0];
clearCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 currentCompactedKVs = 13;
clearCurrentRow() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
clearData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes data = 4;
clearDeadNodes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated string deadNodes = 2;
clearDeadServers(List<ServerName>) - Method in interface org.apache.hadoop.hbase.client.Admin
Clear dead region servers from master.
clearDeadServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
clearDeadServers(RpcController, MasterProtos.ClearDeadServersRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
clearDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .hbase.pb.BulkDeleteRequest.DeleteType deleteType = 2;
clearEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional bytes endKey = 3;
clearEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bytes endRow = 2;
clearEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int64 endTime = 6;
clearFiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Clears all the files currently in use and returns them.
clearFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
clearFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional string filter = 8;
clearFilters() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
clearFilters() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
clearHashCache() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
clearHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int32 heapSizeMB = 4;
clearId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional int64 id = 4;
clearInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional bool inMemory = 4;
clearJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jerseyVersion = 5;
clearJmxCache() - Static method in class org.apache.hadoop.metrics2.impl.JmxCacheBuster
For JMX to forget about all previously exported metrics.
clearJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jvmVersion = 2;
clearKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
required bytes key = 1;
clearKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
required string key = 1;
clearLabels() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated string labels = 10;
clearLastAssignment(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
clearLiveNodes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
clearLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional string location = 5;
clearMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int32 maxHeapSizeMB = 5;
clearMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional int32 maxVersions = 4;
clearMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 maxVersions = 7;
clearMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 memstoreSizeMB = 5;
clearMetrics() - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
 
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string name = 1;
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string name = 1;
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
required string name = 1;
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
required bytes name = 1;
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
required string name = 1;
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
required string name = 1;
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
repeated string name = 1;
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string name = 1;
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional string name = 1;
clearNamespace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
repeated string namespace = 1;
clearOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string osVersion = 3;
clearProps() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
clearReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional bool readOnly = 5;
clearReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 readRequestsCount = 7;
clearRegionCache() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Allows flushing the region cache.
clearRegionCache(TableName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Allows flushing the region cache of all locations that pertain to tableName
clearRegionCache() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
clearRegionCache(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
clearRegionCache(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
clearRegionCache() - Method in class org.apache.hadoop.hbase.client.HTable
Explicitly clears the region cache to fetch the latest value from META.
clearRegionReplayEditsSize(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
Clear a region from replayEditsPerRegion.
clearRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional int32 regions = 3;
clearRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
clearRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
clearRemainingLine() - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
 
clearRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional int64 requests = 4;
clearRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int64 requests = 3;
clearRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string restVersion = 1;
clearRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 rootIndexSizeKB = 9;
clearRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes row = 1;
clearRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required uint32 rowBatchSize = 4;
clearRows() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
clearRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
required uint64 rowsDeleted = 1;
clearScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .hbase.pb.Scan scan = 1;
clearServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string serverVersion = 4;
clearSnapshot(long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
The passed snapshot was successfully persisted; it can be let go.
clearSnapshot(long) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Clears the current snapshot of the Memstore.
clearStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int64 startCode = 2;
clearStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional bytes startKey = 2;
clearStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bytes startRow = 1;
clearStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int64 startTime = 5;
clearStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefileIndexSizeMB = 6;
clearStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefiles = 3;
clearStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefileSizeMB = 4;
clearStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 stores = 2;
clearTerminal() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
clearTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
optional uint64 timestamp = 3;
clearTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional int64 timestamp = 3;
clearTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 totalCompactingKVs = 12;
clearTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 totalStaticBloomSizeKB = 11;
clearTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 totalStaticIndexSizeKB = 10;
clearTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional int32 ttl = 3;
clearValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string value = 2;
clearValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
required string value = 2;
clearValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string value = 2;
clearValues() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
clearVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
optional uint64 versionsDeleted = 2;
clearWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 writeRequestsCount = 8;
clearZNodes(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
ClickjackingPreventionFilter - Class in org.apache.hadoop.hbase.http
 
ClickjackingPreventionFilter() - Constructor for class org.apache.hadoop.hbase.http.ClickjackingPreventionFilter
 
Client - Class in org.apache.hadoop.hbase.rest.client
A wrapper around HttpClient which provides some useful function and semantics for interacting with the REST gateway.
Client() - Constructor for class org.apache.hadoop.hbase.rest.client.Client
Default Constructor
Client(Cluster) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
Constructor
Client(Cluster, boolean) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
Constructor
CLIENT_PORT_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The ZK client port key in the ZK properties map.
CLIENT_SIDE_METRICS_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
Set this key to true to enable metrics collection of client requests.
ClientBackoffPolicy - Interface in org.apache.hadoop.hbase.client.backoff
Configurable policy for the amount of time a client should wait for a new request to the server when given the server load statistics.
ClientBackoffPolicyFactory - Class in org.apache.hadoop.hbase.client.backoff
 
ClientBackoffPolicyFactory.NoBackoffPolicy - Class in org.apache.hadoop.hbase.client.backoff
Default backoff policy that doesn't create any backoff for the client, regardless of load
ClientBackoffPolicyFactory.NoBackoffPolicy(Configuration) - Constructor for class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
 
ClientExceptionsUtil - Class in org.apache.hadoop.hbase.exceptions
 
ClientScanner - Class in org.apache.hadoop.hbase.client
Implements the scanner interface for the HBase client.
ClientScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
Create a new ClientScanner for the specified table Note that the passed Scan's start row maybe changed changed.
ClientSideRegionScanner - Class in org.apache.hadoop.hbase.client
A client scanner for a region opened for read-only on the client side.
ClientSideRegionScanner(Configuration, FileSystem, Path, HTableDescriptor, HRegionInfo, Scan, ScanMetrics) - Constructor for class org.apache.hadoop.hbase.client.ClientSideRegionScanner
 
ClientSimpleScanner - Class in org.apache.hadoop.hbase.client
ClientSimpleScanner implements a sync scanner behaviour.
ClientSimpleScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - Constructor for class org.apache.hadoop.hbase.client.ClientSimpleScanner
 
ClientSnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
Class to help with dealing with a snapshot description on the client side.
ClientUtil - Class in org.apache.hadoop.hbase.client
 
ClientUtil() - Constructor for class org.apache.hadoop.hbase.client.ClientUtil
 
ClockOutOfSyncException - Exception in org.apache.hadoop.hbase
This exception is thrown by the master when a region server clock skew is too high.
ClockOutOfSyncException(String) - Constructor for exception org.apache.hadoop.hbase.ClockOutOfSyncException
 
clone() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
clone() - Method in class org.apache.hadoop.hbase.KeyValue
Clones a KeyValue.
clone() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
clone() - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
 
clone() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
 
clone() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
Public exposure of Object.clone() in order to allow clients to easily capture current state.
clone() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
cloneAndAddTags(Cell, List<Tag>) - Static method in class org.apache.hadoop.hbase.KeyValue
Create a new KeyValue by copying existing cell and adding new tags
cloneFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
cloneForReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
Clone a StoreFile for opening private reader.
cloneQualifier(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
cloneRegionInfo(HRegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
Create a new HRegionInfo from the snapshot region info.
cloneRegionInfo(TableName, HRegionInfo) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
 
cloneRow(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
get individual arrays for tests
cloneSnapshot(byte[], TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneSnapshot(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create a new table by cloning the snapshot content.
cloneSnapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
CloneSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
Handler to Clone a snapshot.
CloneSnapshotHandler(MasterServices, HBaseProtos.SnapshotDescription, HTableDescriptor, boolean) - Constructor for class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
 
cloneValue(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
close() - Method in interface org.apache.hadoop.hbase.client.Admin
 
close() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Performs a BufferedMutator.flush() and releases any resources held.
close() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
close() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
close() - Method in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
 
close() - Method in interface org.apache.hadoop.hbase.client.Connection
 
close() - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
 
close() - Method in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
 
close() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
close() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
close() - Method in class org.apache.hadoop.hbase.client.HTable
 
close() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
Closes the internal Connection.
close() - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Closes all the HTable instances , belonging to all tables in the table pool.
close() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
close() - Method in class org.apache.hadoop.hbase.client.MetaScanner.MetaScannerVisitorBase
 
close() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
close() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
Closes the scanner and releases any resources it has allocated
close() - Method in interface org.apache.hadoop.hbase.client.Table
Releases any resources held or pending changes in internal buffers.
close() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
 
close() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
Close this filesystem object
close() - Method in class org.apache.hadoop.hbase.hbtop.screen.Screen
 
close() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
close() - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
 
close() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
close() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
 
close() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
Releases the compressor this writer uses to compress blocks into the compressor pool.
close() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
Releases the resources used.
close() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
Close stream(s) if necessary.
close() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
 
close() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
close(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
Close method with optional evictOnClose
close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
close(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
close() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Close the stream socket to handle RS CLOSE_WAIT.
close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
 
close() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
close() - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
Stop all threads related to this client.
close() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
close(Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
 
close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
close() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
 
close() - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueDeserializer
 
close() - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
 
close(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
 
close(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
Closes the writer, in this case flush table commits.
close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Closes the split.
close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Closes the split.
close() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
 
close() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
 
close() - Method in interface org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
 
close() - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
Shutdown the thread pools and release rpc resources
close() - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
Best effort attempt to close the threadpool via Thread.interrupt.
close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
 
close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
 
close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
close() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
close() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
close() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Cleanup method on operation completion
close() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
 
close() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
 
close() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
Close this instance since it won't be used any more, try to put the chunks back to pool
close() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Close down this HRegion.
close(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Close down this HRegion.
CLOSE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
close() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
close() - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
Closes the scanner and releases any resources it has allocated
close() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
close() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Close the KeyValue scanner.
close() - Method in class org.apache.hadoop.hbase.regionserver.Leases
Shut down this Leases instance.
close() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
Close instance since it won't be used any more, try to put the chunks back to pool
close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
close() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
Close the region's metrics as this region is closing.
close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
close() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
Close the table's metrics as all the region are closing.
close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
 
close() - Method in interface org.apache.hadoop.hbase.regionserver.Store
Close all the readers We don't need to worry about subsequent requests because the Region holds a write lock that will prevent any more reads or writes.
close(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
close() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
 
close() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
close() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
close() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
close() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
close() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
close() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
close() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
 
close() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
close() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
close() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
close() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
 
close() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
 
close() - Method in class org.apache.hadoop.hbase.rest.ResultGenerator
 
close() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
 
close() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
close() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
close() - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
close() - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
 
close(ChannelHandlerContext, ChannelPromise) - Method in class org.apache.hadoop.hbase.security.SaslWrapHandler
 
close() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
close() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Flushes and closes (I think, in the superclass) the stream.
close() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
close() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
close() - Method in class org.apache.hadoop.hbase.util.MultiHConnection
Close the open connections and shutdown the batchpool
close() - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
 
close() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
close() - Method in interface org.apache.hadoop.hbase.wal.WAL
Caller no longer needs any edits from this WAL.
close() - Method in class org.apache.hadoop.hbase.wal.WALFactory
Shutdown all WALs and clean up any underlying storage.
close() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
shutdown utstanding WALs and clean up any persisted state.
close() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
close() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Close the connection to ZooKeeper.
CLOSE_PARAN_NODE - Static variable in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
 
closeAfterLeasesExpire() - Method in class org.apache.hadoop.hbase.regionserver.Leases
Shuts down this lease instance when all outstanding leases expire.
closeAllRegions(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Closes all regions.
closeAndArchiveCompactedFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
closeAndArchiveCompactedFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
Closes and archives the compacted files under this store
closeAndCleanCompleted - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
closeConnection(RpcServer.Connection) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
closed - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
closed - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
CLOSED_PARAN - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
ClosedRegionHandler - Class in org.apache.hadoop.hbase.master.handler
Handles CLOSED region event on Master.
ClosedRegionHandler(Server, AssignmentManager, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
 
closeHRegion(HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
This will do the necessary cleanup a call to HRegion.createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor) requires.
closeInternal() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
closeInternal() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcClient
 
closeInternal() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcClient
 
CloseMetaHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handles closing of the root region on a region server.
CloseMetaHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseMetaHandler
 
closeOutputStream - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
True if we opened the outputStream (and so will close it).
closeQueue(ReplicationSourceInterface) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Clear the references to the specified old source
closeReader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
closeReceivers() - Method in class org.apache.hadoop.hbase.trace.SpanReceiverHost
Calls close() on all SpanReceivers created by this SpanReceiverHost.
closeRecoveredQueue(ReplicationSourceInterface) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Clear the references to the specified old source
closeRegion(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Close a region.
closeRegion(byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
Close a region.
closeRegion(ServerName, HRegionInfo) - Method in interface org.apache.hadoop.hbase.client.Admin
Close a region.
closeRegion(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Close a region.
closeRegion(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Close a region.
closeRegion(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Close a region.
closeRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to close a region given a region name using admin protocol.
closeRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, byte[], int, ServerName, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to close a region given a region name using admin protocol.
closeRegion(String, boolean, CloseRegionCoordination.CloseRegionDetails, ServerName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Close asynchronously a region, can be called from the master or internally by the regionserver when stopping.
closeRegion(RpcController, AdminProtos.CloseRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Close a region on the region server.
CloseRegionCoordination - Interface in org.apache.hadoop.hbase.coordination
Coordinated operations for close region handlers.
closeRegionCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
CloseRegionCoordination.CloseRegionDetails - Interface in org.apache.hadoop.hbase.coordination
Marker interface for region closing tasks.
CloseRegionHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handles closing of a region on a region server.
CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
This method used internally by the RegionServer to close out regions.
CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails, ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
 
CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails, EventType) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
 
CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails, EventType, ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
 
closeRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
closeRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
closeRegionOperation() - Method in interface org.apache.hadoop.hbase.regionserver.Region
Closes the region operation lock.
closeRegionOperation(Region.Operation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Closes the region operation lock.
closeRegionSilentlyAndWait(ClusterConnection, ServerName, HRegionInfo, long) - Static method in class org.apache.hadoop.hbase.master.ServerManager
Contacts a region server and waits up to timeout ms to close the region.
closeRegionSilentlyAndWait(HConnection, ServerName, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
Contacts a region server and waits up to hbase.hbck.close.timeout ms (default 120s) to close the region.
closeRegionWithEncodedRegionName(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
For expert-admins.
closeRegionWithEncodedRegionName(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
For expert-admins.
closeScanner(int, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
closeScanner(int, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
closeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
closeScanner(int) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Closes the scanner.
closeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
closeTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Close the Table and related objects that were initialized via TableInputFormatBase.initializeTable(Connection, TableName).
closeTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Close the Table and related objects that were initialized via TableInputFormatBase.initializeTable(Connection, TableName).
closeTablePool(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Closes all the HTable instances , belonging to the given table, in the table pool.
closeTablePool(byte[]) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
closing - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
Cluster - Class in org.apache.hadoop.hbase.rest.client
A list of 'host:port' addresses of HTTP servers operating as a single entity, for example multiple redundant web service gateways.
Cluster() - Constructor for class org.apache.hadoop.hbase.rest.client.Cluster
Constructor
Cluster(List<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Cluster
Constructor
CLUSTER_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
Cluster is in distributed mode or not
CLUSTER_ID_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for cluster ID
CLUSTER_ID_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
CLUSTER_ID_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CLUSTER_ID_FILE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
name of the file for unique cluster ID
CLUSTER_ID_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
CLUSTER_ID_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CLUSTER_IS_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
Cluster is fully-distributed
CLUSTER_IS_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
Cluster is standalone or pseudo-distributed
CLUSTER_REQUESTS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
ClusterConnection - Interface in org.apache.hadoop.hbase.client
Internal methods on Connection that should not be used by user code.
clusterConnection - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
Cluster connection to be shared by services.
ClusterId - Class in org.apache.hadoop.hbase
The identifier for this cluster.
ClusterId() - Constructor for class org.apache.hadoop.hbase.ClusterId
New ClusterID.
ClusterId(String) - Constructor for class org.apache.hadoop.hbase.ClusterId
 
clusterId - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
clusterIds - Variable in class org.apache.hadoop.hbase.wal.WALKey
 
clusterIdZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
ClusterLoadState - Class in org.apache.hadoop.hbase.master.balancer
Class used to hold the current state of the cluster and how balanced it is.
ClusterLoadState(Map<ServerName, List<HRegionInfo>>) - Constructor for class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
 
ClusterMarkingEntryFilter - Class in org.apache.hadoop.hbase.replication
Filters out entries with our peerClusterId (i.e.
ClusterMarkingEntryFilter(UUID, UUID, ReplicationEndpoint) - Constructor for class org.apache.hadoop.hbase.replication.ClusterMarkingEntryFilter
 
clusterStateZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
ClusterStatus - Class in org.apache.hadoop.hbase
Status information on the HBase cluster.
ClusterStatus() - Constructor for class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 0.96 (HBASE-6038). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
ClusterStatus(String, String, List<ServerName>, ServerName) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, Map<String, RegionState>, String[], Boolean) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, Set<RegionState>, String[], Boolean) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
 
clusterStatus - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
ClusterStatusChore - Class in org.apache.hadoop.hbase.master.balancer
Chore that will feed the balancer the cluster status.
ClusterStatusChore(HMaster, LoadBalancer) - Constructor for class org.apache.hadoop.hbase.master.balancer.ClusterStatusChore
 
ClusterStatusPublisher - Class in org.apache.hadoop.hbase.master
Class to publish the cluster status to the client.
ClusterStatusPublisher(HMaster, Configuration, Class<? extends ClusterStatusPublisher.Publisher>) - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher
 
ClusterStatusPublisher() - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher
 
ClusterStatusPublisher.MulticastPublisher - Class in org.apache.hadoop.hbase.master
 
ClusterStatusPublisher.MulticastPublisher() - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
 
ClusterStatusPublisher.Publisher - Interface in org.apache.hadoop.hbase.master
 
clusterStatusTracker - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
ClusterStatusTracker - Class in org.apache.hadoop.hbase.zookeeper
Tracker on cluster settings up in zookeeper.
ClusterStatusTracker(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
Creates a cluster status tracker.
cmdLineArgs - Variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
cmp(int) - Method in enum org.apache.hadoop.hbase.util.Order
Returns the adjusted trichotomous value according to the ordering imposed by this Order.
code() - Method in enum org.apache.hadoop.hbase.security.access.Permission.Action
 
code - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
The code for this method.
code - Variable in enum org.apache.hadoop.hbase.wal.WALKey.Version
 
Codec - Interface in org.apache.hadoop.hbase.codec
Encoder/Decoder for Cell.
codec - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
Codec.Decoder - Interface in org.apache.hadoop.hbase.codec
Implementations should implicitly clean up any resources allocated when the Decoder/CellScanner runs off the end of the cell block.
Codec.Encoder - Interface in org.apache.hadoop.hbase.codec
Call flush when done.
CodecException - Exception in org.apache.hadoop.hbase.codec
Thrown when problems in the codec whether setup or context.
CodecException() - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
 
CodecException(String) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
 
CodecException(Throwable) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
 
CodecException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
 
codeToType(byte) - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
Cannot rely on enum ordinals .
codeToType(byte) - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
Cannot rely on enum ordinals .
colDescFromHbase(HColumnDescriptor) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a new Thrift ColumnDescriptor "struct" based on an Hbase HColumnDescriptor object.
colDescFromThrift(ColumnDescriptor) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a new Hbase HColumnDescriptor object based on a Thrift ColumnDescriptor "struct".
colFamTimeRangeMap - Variable in class org.apache.hadoop.hbase.client.Query
 
colFamTimeRangeMap - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
CollectionBackedScanner - Class in org.apache.hadoop.hbase.util
Utility scanner that wraps a sortable collection and serves as a KeyValueScanner.
CollectionBackedScanner(SortedSet<Cell>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
CollectionBackedScanner(SortedSet<Cell>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
CollectionBackedScanner(List<Cell>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
CollectionBackedScanner(List<Cell>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
CollectionBackedScanner(KeyValue.KVComparator, Cell...) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
CollectionUtils - Class in org.apache.hadoop.hbase.util
Utility methods for dealing with Collections, including treating null collections as empty.
CollectionUtils() - Constructor for class org.apache.hadoop.hbase.util.CollectionUtils
 
COLON - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for colon (:)
Color - Enum in org.apache.hadoop.hbase.hbtop.terminal
Terminal color definitions.
color(Color, Color, boolean, boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
name of column
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
column name
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
name of column whose value is to be deleted
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
name of column whose value is to be deleted
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
column name
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
column name
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
column name
column - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
column - Variable in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
COLUMN_FAMILY_DELIM_ARRAY - Static variable in class org.apache.hadoop.hbase.KeyValue
 
COLUMN_FAMILY_DELIMITER - Static variable in class org.apache.hadoop.hbase.KeyValue
Colon character in UTF-8
COLUMN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
COLUMN_LIST - Static variable in class org.apache.hadoop.hbase.mapred.TableInputFormat
space delimited list of columns
COLUMN_VALUE - Static variable in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
COLUMN = 2;
columnBuffer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
columnBuffer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
 
ColumnCountGetFilter - Class in org.apache.hadoop.hbase.filter
Simple filter that returns first N columns on row only.
ColumnCountGetFilter(int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
ColumnDescriptor - Class in org.apache.hadoop.hbase.thrift.generated
 
ColumnDescriptor() - Constructor for class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
ColumnDescriptor(ByteBuffer, int, String, boolean, String, int, int, boolean, int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
ColumnDescriptor(ColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
Performs a deep copy on other.
ColumnDescriptor._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
columnFamilies - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
list of column family descriptors
columnFamily - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
columnFamily - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
ColumnInterpreter<T,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,R extends com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.coprocessor
Defines how value for specific column is interpreted and provides utility methods like compare, add, multiply etc for them.
ColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
columnLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
 
columnName - Variable in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
ColumnNodeReader - Class in org.apache.hadoop.hbase.codec.prefixtree.decode.column
 
ColumnNodeReader(byte[], ColumnNodeType) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
construct
columnNodeReader - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
 
ColumnNodeType - Enum in org.apache.hadoop.hbase.codec.prefixtree.encode.other
Specifies the type of columnnode writer.
ColumnNodeWriter - Class in org.apache.hadoop.hbase.codec.prefixtree.encode.column
Column nodes can be either family nodes or qualifier nodes, as both sections encode similarly.
ColumnNodeWriter(PrefixTreeBlockMeta, TokenizerNode, ColumnNodeType) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
construct
columnOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
 
ColumnPaginationFilter - Class in org.apache.hadoop.hbase.filter
A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.
ColumnPaginationFilter(int, int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
Initializes filter with an integer offset and limit.
ColumnPaginationFilter(int, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
Initializes filter with a string/bookmark based offset and limit.
ColumnPrefixFilter - Class in org.apache.hadoop.hbase.filter
This filter is used for selecting only those keys with columns that matches a particular prefix.
ColumnPrefixFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
columnQualifier - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
columnQualifier - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
ColumnRangeFilter - Class in org.apache.hadoop.hbase.filter
This filter is used for selecting only those keys with columns that are between minColumn to maxColumn.
ColumnRangeFilter(byte[], boolean, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.ColumnRangeFilter
Create a filter to select those keys with columns that are between minColumn and maxColumn.
ColumnReader - Class in org.apache.hadoop.hbase.codec.prefixtree.decode.column
Position one of these appropriately in the data block and you can call its methods to retrieve the family or qualifier at the current position.
ColumnReader(byte[], ColumnNodeType) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
construct
columns - Variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
 
columns - Variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
The grouping columns.
columns - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
Keeps track of columns and versions
columns - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
List of columns to return, null for all columns
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
List of columns to return, null for all columns
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
List of columns to return, null for all columns
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
List of columns to return, null for all columns
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
columns to scan.
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
columns to scan.
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
the columns you want returned
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
columns to scan.
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
columns to scan.
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
columns - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
 
columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
COLUMNS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
COLUMNS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
COLUMNS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
ColumnSchemaMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
ColumnSchemaMessage.ColumnSchema - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema
ColumnSchemaMessage.ColumnSchema.Attribute - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute
ColumnSchemaMessage.ColumnSchema.Attribute.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute
ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
ColumnSchemaMessage.ColumnSchema.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema
ColumnSchemaMessage.ColumnSchemaOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
ColumnSchemaModel - Class in org.apache.hadoop.hbase.rest.model
Representation of a column family schema.
ColumnSchemaModel() - Constructor for class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
Default constructor
ColumnSectionWriter - Class in org.apache.hadoop.hbase.codec.prefixtree.encode.column
Takes the tokenized family or qualifier data and flattens it into a stream of bytes.
ColumnSectionWriter() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
construct
ColumnSectionWriter(PrefixTreeBlockMeta, Tokenizer, ColumnNodeType) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
 
ColumnTracker - Interface in org.apache.hadoop.hbase.regionserver.querymatcher
Implementing classes of this interface will be used for the tracking and enforcement of columns and numbers of versions and timeToLive during the course of a Get or Scan operation.
columnValues - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
columnValues - Variable in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
com.google.protobuf - package com.google.protobuf
 
combine(Record) - Method in class org.apache.hadoop.hbase.hbtop.Record
 
CombinedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
CombinedBlockCache is an abstraction layer that combines LruBlockCache and BucketCache.
CombinedBlockCache(LruBlockCache, BlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
CombinedBlockCache.CombinedCacheStats - Class in org.apache.hadoop.hbase.io.hfile
 
combinedCacheStats - Variable in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
combineWith(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
Combines the request with other request.
comConf - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
 
COMMA - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for a comma
CommandDescription - Class in org.apache.hadoop.hbase.hbtop.screen.help
Represents a description of a command that we can execute in the top screen.
CommandDescription(String, String) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription
 
CommandDescription(List<String>, String) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription
 
commitOpenOnMasterSide(AssignmentManager, HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
Commits opening operation on HM side (steps required for "commit" are determined by coordination implementation).
commitOpenOnMasterSide(AssignmentManager, HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
 
commitStoreFile(String, Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Move the file from a build/temp location to the main family store directory.
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
commitWriter(T, Compactor.FileDetails, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
commitWriter(DateTieredMultiFileWriter, Compactor.FileDetails, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactor
 
commitWriter(StoreFile.Writer, Compactor.FileDetails, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
 
commitWriter(StripeMultiFileWriter, Compactor.FileDetails, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
 
commitWriters(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
Commit all writers.
commitWriters(long, boolean, Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
 
compact(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact a table.
compact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact a column family within a table.
compact(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a table.
compact(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
compact(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
compact(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a column family within a table.
compact(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
compact(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
compact(ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
 
compact(CompactionRequest, Compactor.InternalScannerFactory, Compactor.CellSinkFactory<T>, ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
compact(CompactionRequest, List<Long>, ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactor
 
compact(CompactionRequest, ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
Do a minor/major compaction on an explicit set of storefiles from a Store.
compact(CompactionRequest, List<byte[]>, byte[], byte[], ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
 
compact(CompactionRequest, int, long, byte[], byte[], byte[], byte[], ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
 
compact(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
compact(CompactionContext, Store, ThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
compact(CompactionContext, Store, ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
compact(CompactionContext, ThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Compact the StoreFiles.
compact(CompactionContext, ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
compact(boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Synchronously compact all stores in the region.
compact(CompactionContext, ThroughputController) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Deprecated.
see compact(CompactionContext, ThroughputController, User)
compact(CompactionContext, ThroughputController, User) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
compact(ByteBuffer, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
compact(ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
compact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
compact(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
 
compact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
compactBloom() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
Compact the Bloom filter before writing metadata & data to disk.
compactBloom() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
compactBloom() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
 
COMPACTCHECKER_INTERVAL_MULTIPLIER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
COMPACTED_CELLS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_CELLS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_CELLS_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_CELLS_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_INPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_INPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_OUTPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_OUTPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CompactedHFilesDischargeHandler - Class in org.apache.hadoop.hbase.regionserver
Event handler that handles the removal and archival of the compacted hfiles
CompactedHFilesDischargeHandler(Server, EventType, HStore) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischargeHandler
 
CompactedHFilesDischarger - Class in org.apache.hadoop.hbase.regionserver
A chore service that periodically cleans up the compacted files when there are no active readers using those compacted files and also helps in clearing the block cache with these compacted file entries
CompactedHFilesDischarger(int, Stoppable, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
 
CompactedHFilesDischarger(int, Stoppable, RegionServerServices, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
 
compactForTesting(Collection<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
Compact a list of files for testing.
COMPACTION - Static variable in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by HBase Shell interface to access this metadata attribute which denotes if the table is compaction enabled
COMPACTION_EVENT_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Key for compaction event which contains the compacted storefiles in FileInfo
COMPACTION_INPUT_FILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_INPUT_FILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_INPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_INPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_KV_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the maximum batch of KVs to be used in flushes and compactions
COMPACTION_KV_MAX_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
COMPACTION_OUTPUT_FILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_OUTPUT_FILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_OUTPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_OUTPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_POLICY_CLASS_FOR_DATE_TIERED_WINDOWS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
COMPACTION_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
compactionCompression - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
CompactionConfiguration - Class in org.apache.hadoop.hbase.regionserver.compactions
Compaction configuration for a particular instance of HStore.
CompactionContext - Class in org.apache.hadoop.hbase.regionserver.compactions
This class holds all "physical" details necessary to run a compaction, and abstracts away the details specific to a particular compaction.
CompactionContext() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
 
compactionKVMax - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
CompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
A compaction policy determines how to select files for compaction, how to compact them, and how to generate the compacted files.
CompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
 
compactionPolicy - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
CompactionProgress - Class in org.apache.hadoop.hbase.regionserver.compactions
This class holds information relevant for tracking the progress of a compaction.
CompactionProgress(long) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
Constructor
CompactionRequest - Class in org.apache.hadoop.hbase.regionserver.compactions
This class holds all logical details necessary to run a compaction.
CompactionRequest() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
This ctor should be used by coprocessors that want to subclass CompactionRequest.
CompactionRequest(Collection<StoreFile>) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
CompactionRequestor - Interface in org.apache.hadoop.hbase.regionserver
 
COMPACTIONS_COMPLETED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
COMPACTIONS_COMPLETED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
COMPACTIONS_FAILED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
COMPACTIONS_FAILED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
COMPACTIONS_QUEUED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
COMPACTIONS_QUEUED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
CompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
Query matcher for compaction.
CompactionScanQueryMatcher(ScanInfo, DeleteTracker, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
CompactionThroughputControllerFactory - Class in org.apache.hadoop.hbase.regionserver.throttle
 
CompactionTool - Class in org.apache.hadoop.hbase.regionserver
 
CompactionTool() - Constructor for class org.apache.hadoop.hbase.regionserver.CompactionTool
 
CompactionWindow - Class in org.apache.hadoop.hbase.regionserver.compactions
Base class for compaction window implementation.
CompactionWindow() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionWindow
 
CompactionWindowFactory - Class in org.apache.hadoop.hbase.regionserver.compactions
For creating compaction window.
CompactionWindowFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionWindowFactory
 
Compactor<T extends Compactor.CellSink> - Class in org.apache.hadoop.hbase.regionserver.compactions
A compactor is a compaction algorithm associated a given policy.
compactor - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
Compactor.CellSink - Interface in org.apache.hadoop.hbase.regionserver.compactions
 
Compactor.CellSinkFactory<S> - Interface in org.apache.hadoop.hbase.regionserver.compactions
 
Compactor.FileDetails - Class in org.apache.hadoop.hbase.regionserver.compactions
The sole reason this class exists is that java has no ref/out/pointer parameters.
Compactor.FileDetails() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
 
Compactor.InternalScannerFactory - Interface in org.apache.hadoop.hbase.regionserver.compactions
 
compactRecentForTestingAssumingDefaultPolicy(int) - Method in class org.apache.hadoop.hbase.regionserver.HStore
This method tries to compact N recent files for testing.
compactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact an individual region.
compactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact a column family within a region.
compactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact an individual region.
compactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a column family within a region.
compactRegion(RpcController, AdminProtos.CompactRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Compact a region on the region server.
compactRegionServer(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact all regions on the region server
compactRegionServer(ServerName, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact all regions on the region server
CompactSplitThread - Class in org.apache.hadoop.hbase.regionserver
Compact region on request and then run split if appropriate
compactSplitThread - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
compactStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
This is a helper function that compact all the stores synchronously It is used by utilities and testing
comparator - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
 
comparator - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
comparator - Variable in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker
 
comparator - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Key comparator
comparator - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Key comparator.
comparator() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
comparator - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
Comparator for plain key/values; i.e.
comparator() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
comparator - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
comparator - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
comparator - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
 
comparator() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
comparator() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
comparator - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
Comparator used to compare Bloom filter keys
comparator() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
COMPARATOR - Static variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.ZNodeComparator
 
compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparator
 
compare(Cell, Cell, boolean) - Static method in class org.apache.hadoop.hbase.CellComparator
Compare cells.
compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparator.RowComparator
 
compare(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
compare(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
compare(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
compare(TokenizerNode, TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenDepthComparator
 
compare(T, T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This takes care if either of arguments are null.
compare(HDFSBlocksDistribution.HostAndWeight, HDFSBlocksDistribution.HostAndWeight) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
 
compare(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
Compare the timestamp to timerange.
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Compares the Key of a cell -- with fields being more significant in this order: rowkey, colfam/qual, timestamp, type, mvcc
compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
Compare key portion of a KeyValue for keys in hbase:meta table.
compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.RawBytesComparator
 
compare(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.RowOnlyComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable.KeyValueWritableComparator
 
compare(RegionPlan, RegionPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator
 
compare(KeyValueScanner, KeyValueScanner) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
 
compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
Compares two KeyValue
compare(Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.LogsComparator
 
compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
 
compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
 
compare(String, String) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.ZNodeComparator
 
compareCell(Cell, Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
compareColumns(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
 
compareColumns(byte[], int, int, int, byte[], int, int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareColumns(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareCommonFamilyPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.CellComparator
 
compareCommonQualifierPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.CellComparator
 
compareCommonRowPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.CellComparator
 
compareFamilies(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
 
compareFamilies(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
CompareFilter - Class in org.apache.hadoop.hbase.filter
This is a generic filter to be used to filter by comparison.
CompareFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
Constructor.
CompareFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
Comparison operators.
compareFlatKey(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparator
 
compareFlatKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Compares left to right assuming that left,loffset,llength and right,roffset,rlength are full KVs laid out in a flat byte[]s.
compareFlatKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareFlatKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.RawBytesComparator
Deprecated.
Since 0.99.2.
compareIgnoringPrefix(int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Overridden
compareIgnoringPrefix(int, byte[], int, int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.KeyValue.SamePrefixComparator
Compare two keys assuming that the first n bytes are the same.
compareKey(KeyValue.KVComparator, byte[], int, int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
compareKey(KeyValue.KVComparator, Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
compareKey(KeyValue.KVComparator, byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
Compare the given key against the current key
compareKey(KeyValue.KVComparator, Cell) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
 
compareKey(KeyValue.KVComparator, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
compareKey(KeyValue.KVComparator, Cell) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
compareKey(KeyValue.KVComparator, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
Compare the given key against the current key
compareKey(KeyValue.KVComparator, Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
compareKey(KeyValue.KVComparator, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
compareKey(KeyValue.KVComparator, Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
compareKey(KeyValue.KVComparator, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
compareKey(KeyValue.KVComparator, Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
compareKey(Cell, byte[], int, int, byte[], int, int, byte[], int, int, long, byte) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareKeyForNextColumn(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
compareKeyForNextRow(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
compareOnlyKeyPortion(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareOnlyKeyPortion(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
 
compareOnlyKeyPortion(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.RawBytesComparator
 
compareOp - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
 
compareOp - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
compareOp - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
comparison to make on the value
compareOpFromThrift(TCompareOp) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
 
compareQualifiers(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
 
compareResults(Result, Result) - Static method in class org.apache.hadoop.hbase.client.Result
Does a deep comparison of two Results, down to the byte arrays.
compareRowKey(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Compares the only the user specified portion of a Key.
compareRowKey(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
Override the row key comparison to parse and compare the meta row key parts.
compareRows(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
Do not use comparing rows from hbase:meta.
compareRows(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellComparator
Do not use comparing rows from hbase:meta.
compareRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareRows(Cell, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Get the b[],o,l for left and right rowkey portions and compare.
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
 
compareTimestamps(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
Compares cell's timestamps in DESCENDING order.
compareTimestamps(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareTo(Object) - Method in class org.apache.hadoop.hbase.client.Action
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Get
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Increment
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Mutation
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RowMutations
 
compareTo(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
compareTo(Runnable) - Method in class org.apache.hadoop.hbase.executor.EventHandler
Default prioritized runnable comparator which implements a FIFO ordering.
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BitComparator
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
Special compareTo method for subclasses, to avoid copying byte[] unnecessarily.
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.LongComparator
 
compareTo(MultiRowRangeFilter.RowRange) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
compareTo(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
compareTo(Size) - Method in class org.apache.hadoop.hbase.hbtop.field.Size
 
compareTo(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
compareTo(HRegionInfo) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
compareTo(HRegionLocation) - Method in class org.apache.hadoop.hbase.HRegionLocation
 
compareTo(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Compares the descriptor with another descriptor which is passed as a parameter.
compareTo(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
compareTo(ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Define the sort order of the BytesWritable.
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Compares the bytes in this object to the specified byte array
compareTo(Delayed) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
compareTo(Import.KeyValueWritableComparable) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable
 
compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Compares this split against the given one.
compareTo(RegionPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlan
Compare the region info.
compareTo(Address) - Method in class org.apache.hadoop.hbase.net.Address
 
compareTo(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
compareTo(ProcedureWALFile) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
compareTo(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
This function will define where in the priority queue the request will end up.
compareTo(MetricsRegionSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
compareTo(MetricsTableSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
compareTo(ServerName) - Method in class org.apache.hadoop.hbase.ServerName
 
compareTo(TableName) - Method in class org.apache.hadoop.hbase.TableName
For performance reasons, the ordering is not lexicographic.
compareTo(AlreadyExists) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
compareTo(BatchMutation) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
compareTo(ColumnDescriptor) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
compareTo(Hbase.append_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
compareTo(Hbase.append_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
compareTo(Hbase.atomicIncrement_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
compareTo(Hbase.atomicIncrement_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
compareTo(Hbase.checkAndPut_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
compareTo(Hbase.checkAndPut_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
compareTo(Hbase.compact_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
compareTo(Hbase.compact_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
compareTo(Hbase.createTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
compareTo(Hbase.createTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
compareTo(Hbase.deleteAll_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
compareTo(Hbase.deleteAll_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
compareTo(Hbase.deleteAllRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
compareTo(Hbase.deleteAllRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
compareTo(Hbase.deleteAllRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
compareTo(Hbase.deleteAllRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
compareTo(Hbase.deleteAllTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
compareTo(Hbase.deleteAllTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
compareTo(Hbase.deleteTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
compareTo(Hbase.deleteTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
compareTo(Hbase.disableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
compareTo(Hbase.disableTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
compareTo(Hbase.enableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
compareTo(Hbase.enableTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
compareTo(Hbase.get_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
compareTo(Hbase.get_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
compareTo(Hbase.getColumnDescriptors_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
compareTo(Hbase.getColumnDescriptors_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
compareTo(Hbase.getRegionInfo_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
compareTo(Hbase.getRegionInfo_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
compareTo(Hbase.getRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
compareTo(Hbase.getRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
compareTo(Hbase.getRowOrBefore_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
compareTo(Hbase.getRowOrBefore_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
compareTo(Hbase.getRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
compareTo(Hbase.getRows_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
compareTo(Hbase.getRowsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
compareTo(Hbase.getRowsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
compareTo(Hbase.getRowsWithColumns_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
compareTo(Hbase.getRowsWithColumns_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
compareTo(Hbase.getRowsWithColumnsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
compareTo(Hbase.getRowsWithColumnsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
compareTo(Hbase.getRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
compareTo(Hbase.getRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
compareTo(Hbase.getRowWithColumns_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
compareTo(Hbase.getRowWithColumns_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
compareTo(Hbase.getRowWithColumnsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
compareTo(Hbase.getRowWithColumnsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
compareTo(Hbase.getTableNames_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
compareTo(Hbase.getTableNames_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
compareTo(Hbase.getTableRegions_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
compareTo(Hbase.getTableRegions_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
compareTo(Hbase.getVer_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
compareTo(Hbase.getVer_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
compareTo(Hbase.getVerTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
compareTo(Hbase.getVerTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
compareTo(Hbase.increment_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
compareTo(Hbase.increment_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
compareTo(Hbase.incrementRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
compareTo(Hbase.incrementRows_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
compareTo(Hbase.isTableEnabled_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
compareTo(Hbase.isTableEnabled_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
compareTo(Hbase.majorCompact_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
compareTo(Hbase.majorCompact_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
compareTo(Hbase.mutateRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
compareTo(Hbase.mutateRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
compareTo(Hbase.mutateRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
compareTo(Hbase.mutateRows_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
compareTo(Hbase.mutateRowsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
compareTo(Hbase.mutateRowsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
compareTo(Hbase.mutateRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
compareTo(Hbase.mutateRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
compareTo(Hbase.scannerClose_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
compareTo(Hbase.scannerClose_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
compareTo(Hbase.scannerGet_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
compareTo(Hbase.scannerGet_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
compareTo(Hbase.scannerGetList_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
compareTo(Hbase.scannerGetList_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
compareTo(Hbase.scannerOpen_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
compareTo(Hbase.scannerOpen_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
compareTo(Hbase.scannerOpenTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
compareTo(Hbase.scannerOpenTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
compareTo(Hbase.scannerOpenWithPrefix_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
compareTo(Hbase.scannerOpenWithPrefix_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
compareTo(Hbase.scannerOpenWithScan_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
compareTo(Hbase.scannerOpenWithScan_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
compareTo(Hbase.scannerOpenWithStop_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
compareTo(Hbase.scannerOpenWithStop_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
compareTo(Hbase.scannerOpenWithStopTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
compareTo(Hbase.scannerOpenWithStopTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
compareTo(IllegalArgument) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
compareTo(IOError) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
compareTo(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
compareTo(TAppend) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
compareTo(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
compareTo(TColumn) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
compareTo(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
compareTo(TRegionInfo) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
compareTo(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
compareTo(TScan) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
compareTo(TAppend) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
compareTo(TAuthorization) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
compareTo(TCellVisibility) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
compareTo(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
compareTo(TColumnIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
compareTo(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
compareTo(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
compareTo(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
compareTo(THBaseService.append_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
compareTo(THBaseService.append_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
compareTo(THBaseService.checkAndDelete_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
compareTo(THBaseService.checkAndDelete_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
compareTo(THBaseService.checkAndMutate_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
compareTo(THBaseService.checkAndMutate_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
compareTo(THBaseService.checkAndPut_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
compareTo(THBaseService.checkAndPut_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
compareTo(THBaseService.closeScanner_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
compareTo(THBaseService.closeScanner_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
compareTo(THBaseService.deleteMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
compareTo(THBaseService.deleteMultiple_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
compareTo(THBaseService.deleteSingle_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
compareTo(THBaseService.deleteSingle_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
compareTo(THBaseService.exists_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
compareTo(THBaseService.exists_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
compareTo(THBaseService.existsAll_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
compareTo(THBaseService.existsAll_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
compareTo(THBaseService.get_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
compareTo(THBaseService.get_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
compareTo(THBaseService.getAllRegionLocations_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
compareTo(THBaseService.getAllRegionLocations_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
compareTo(THBaseService.getMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
compareTo(THBaseService.getMultiple_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
compareTo(THBaseService.getRegionLocation_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
compareTo(THBaseService.getRegionLocation_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
compareTo(THBaseService.getScannerResults_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
compareTo(THBaseService.getScannerResults_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
compareTo(THBaseService.getScannerRows_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
compareTo(THBaseService.getScannerRows_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
compareTo(THBaseService.increment_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
compareTo(THBaseService.increment_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
compareTo(THBaseService.mutateRow_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
compareTo(THBaseService.mutateRow_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
compareTo(THBaseService.openScanner_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
compareTo(THBaseService.openScanner_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
compareTo(THBaseService.put_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
compareTo(THBaseService.put_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
compareTo(THBaseService.putMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
compareTo(THBaseService.putMultiple_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
compareTo(THRegionInfo) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
compareTo(THRegionLocation) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
compareTo(TIllegalArgument) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
compareTo(TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
compareTo(TIOError) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
compareTo(TMutation) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
compareTo(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
compareTo(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
compareTo(TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
compareTo(TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
compareTo(TServerName) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
compareTo(TTimeRange) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
compareTo(ByteRange) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
Bitwise comparison of each byte in the array.
compareTo(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
 
compareTo(Bytes) - Method in class org.apache.hadoop.hbase.util.Bytes
Define the sort order of the Bytes.
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes
Compares the bytes in this object to the specified byte array
compareTo(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
compareTo(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Lexicographically compare two arrays.
compareTo(WALKey) - Method in class org.apache.hadoop.hbase.wal.WALKey
 
compareTo(WALSplitter.MutationReplay) - Method in class org.apache.hadoop.hbase.wal.WALSplitter.MutationReplay
 
compareToCurrentToken(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
Compare only the bytes within the window of the current token
compareToIgnoreCase(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
compareToTimestamp(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionWindow
Compares the window to a timestamp.
compareVersion(String, String) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
 
compareWithoutRow(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
 
CompatibilityFactory - Class in org.apache.hadoop.hbase
Class that will create many instances of classes provided by the hbase-hadoop{1|2}-compat jars.
CompatibilityFactory() - Constructor for class org.apache.hadoop.hbase.CompatibilityFactory
This is a static only class don't let any instance be created.
CompatibilitySingletonFactory - Class in org.apache.hadoop.hbase
Factory for classes supplied by hadoop compatibility modules.
CompatibilitySingletonFactory() - Constructor for class org.apache.hadoop.hbase.CompatibilitySingletonFactory
This is a static only class don't let anyone create an instance.
CompatibilitySingletonFactory.SingletonStorage - Enum in org.apache.hadoop.hbase
 
compile() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
methods
compile() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
compile() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
Now that all the cells have been added, do the work to reduce them to a series of byte[] fragments that are ready to be written to the output stream.
compile() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
methods
compile() - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
compileFamilies() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
compileMvccVersions() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
compileQualifiers() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
compilerInternals() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
 
compileRows() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
compileTags() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
compileTimestamps() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
compileTypes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
The following "compile" methods do any intermediate work necessary to transform the cell fragments collected during the writing phase into structures that are ready to write to the outputStream.
complete() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
Call to indicate that additional coprocessors further down the execution chain do not need to be invoked.
complete() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
For all time forward, do not throw an error because the process has completed.
complete(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
 
complete() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
Marks the compaction as complete by setting total to current KV count; Total KV count is an estimate, so there might be a discrepancy otherwise.
complete(MultiVersionConcurrencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Mark the MultiVersionConcurrencyControl.WriteEntry as complete and advance the read point as much as possible.
completeAndWait(MultiVersionConcurrencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Complete a MultiVersionConcurrencyControl.WriteEntry that was created by MultiVersionConcurrencyControl.begin() then wait until the read point catches up to our write.
completeCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
completeCacheFlush(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
Complete the cache flush.
completeCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
It works by processing a compaction that's been written to disk.
completeCompaction(Collection<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
It works by processing a compaction that's been written to disk.
completed(Throwable) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
Called after that process() is completed.
completed(Throwable) - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
Called after that process() is completed.
completed(Throwable) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
 
completed(Throwable) - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
 
completeRegionMergeTransaction(RegionServerServices, HRegionInfo, HRegion, HRegion, RegionMergeCoordination.RegionMergeDetails, HRegion) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
Finish off merge transaction
completeRegionMergeTransaction(RegionServerServices, HRegionInfo, HRegion, HRegion, RegionMergeCoordination.RegionMergeDetails, HRegion) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
 
completeSnapshot(Path, Path, FileSystem, FileSystem) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
Reset the manager to allow another snapshot to proceed.
completeSnapshot(Path, Path, FileSystem, FileSystem, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Move the finished snapshot to its final, publicly visible directory - this marks the snapshot as 'complete'.
completeSplitTransaction(RegionServerServices, Region, Region, SplitTransactionCoordination.SplitTransactionDetails, Region) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
Finish off split transaction
completeSplitTransaction(RegionServerServices, Region, Region, SplitTransactionCoordination.SplitTransactionDetails, Region) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
Finish off split transaction, transition the zknode
completionCleanup(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
completionCleanup(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called when the procedure is marked as completed (success or rollback).
completionCleanup(Procedure) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
The procedure in execution completed.
completionCleanup(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
 
components - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists
 
composeAttributeName(String, String) - Static method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
A helper function to compose the attribute name from tablename and costfunction name
CompoundBloomFilter - Class in org.apache.hadoop.hbase.util
A Bloom filter implementation built on top of ByteBloomFilter, encapsulating a set of fixed-size Bloom filters written out at the time of HFile generation into the data block stream, and loaded on demand at query time.
CompoundBloomFilter(DataInput, HFile.Reader) - Constructor for class org.apache.hadoop.hbase.util.CompoundBloomFilter
De-serialization for compound Bloom filter metadata.
CompoundBloomFilterBase - Class in org.apache.hadoop.hbase.util
 
CompoundBloomFilterBase() - Constructor for class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
 
CompoundBloomFilterWriter - Class in org.apache.hadoop.hbase.util
Adds methods required for writing a compound Bloom filter to the data section of an HFile to the CompoundBloomFilter class.
CompoundBloomFilterWriter(int, float, int, int, boolean, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
 
CompoundConfiguration - Class in org.apache.hadoop.hbase
Do a shallow merge of multiple KV configuration pools.
CompoundConfiguration() - Constructor for class org.apache.hadoop.hbase.CompoundConfiguration
Default Constructor.
compress(byte[], Dictionary) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.ByteStringCompressor
 
COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
compressAlgo - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Filled when we read in the trailer.
compressAndEncrypt(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
compressAndEncrypt(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
 
COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
Compression - Class in org.apache.hadoop.hbase.io.compress
Compression related stuff.
compression - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
 
compression - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
Compression.Algorithm - Enum in org.apache.hadoop.hbase.io.compress
Compression algorithms.
COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
COMPRESSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
compressionByName(String) - Static method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
 
CompressionContext - Class in org.apache.hadoop.hbase.regionserver.wal
Context that holds the various dictionaries for compression in WAL.
CompressionContext(Class<? extends Dictionary>, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
 
compressionContext - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
Compression context to use reading.
compressionContext - Variable in class org.apache.hadoop.hbase.regionserver.wal.WriterBase
 
compressionContext - Variable in class org.apache.hadoop.hbase.wal.WALKey
 
CompressionTest - Class in org.apache.hadoop.hbase.util
Compression validation test.
CompressionTest() - Constructor for class org.apache.hadoop.hbase.util.CompressionTest
 
compressor - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
Compressor - Class in org.apache.hadoop.hbase.regionserver.wal
A set of static functions for running our custom WAL compression/decompression.
Compressor() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.Compressor
 
compressor - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
compressTags(OutputStream, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
Compress tags one by one and writes to the OutputStream.
compressTags(OutputStream, ByteBuffer, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
Compress tags one by one and writes to the OutputStream.
computeBitSize(long, double) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
computeCost(BaseLoadBalancer.Cluster, double) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
This is the main cost function.
computeFilename(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
This is a convenience method that computes a new filename with a given file-number.
computeFoldableByteSize(long, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
Increases the given byte size of a Bloom filter until it can be folded by the given factor.
computeHDFSBlocksDistribution(Configuration, HTableDescriptor, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
This is a helper function to compute HDFS block distribution on demand
computeHDFSBlocksDistribution(Configuration, HTableDescriptor, HRegionInfo, Path) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
This is a helper function to compute HDFS block distribution on demand
computeHDFSBlocksDistribution(FileSystem) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Compute the HDFS Block Distribution for this StoreFile
computeHDFSBlocksDistribution(FileSystem, FileStatus, long, long) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Compute HDFS blocks distribution of a given file, or a portion of the file
computeMaxKeys(long, double, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
The maximum number of keys we can put into a Bloom filter of a certain size to get the given error rate, with the given number of hash functions.
computeNumCallQueues(int, float) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
computeNumCallQueues(int, float) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
computePlanForTable(TableName) - Method in interface org.apache.hadoop.hbase.master.normalizer.RegionNormalizer
Computes next optimal normalization plan.
computePlanForTable(TableName) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
Computes next most "urgent" normalization action on the table.
ConcatenatedLists<T> - Class in org.apache.hadoop.hbase.util
A collection class that contains multiple sub-lists, which allows us to not copy lists.
ConcatenatedLists() - Constructor for class org.apache.hadoop.hbase.util.ConcatenatedLists
 
ConcatenatedLists.Iterator - Class in org.apache.hadoop.hbase.util
 
ConcatenatedLists.Iterator() - Constructor for class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
 
CONCURRENT_HASHMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentHashMap
CONCURRENT_HASHMAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentHashMap.Entry
CONCURRENT_HASHMAP_SEGMENT - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentHashMap.Segment
CONCURRENT_SKIPLISTMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentSkipListMap
CONCURRENT_SKIPLISTMAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentSkipListMap Entry
concurrentCallsPerServerHist - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
concurrentVisitReferencedFiles(Configuration, FileSystem, SnapshotManifest, String, SnapshotReferenceUtil.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
 
concurrentVisitReferencedFiles(Configuration, FileSystem, SnapshotManifest, ExecutorService, SnapshotReferenceUtil.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
 
conf - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
conf - Variable in class org.apache.hadoop.hbase.client.HConnectable
 
conf - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
conf - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
conf - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
conf - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
conf - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
conf - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
conf - Variable in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
conf - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
conf - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
conf - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
 
conf - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
conf object
conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.WriterBase
 
conf - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
conf - Variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
conf - Variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
conf - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
 
CONF_CONTEXT_ATTRIBUTE - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
CONF_DEST_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
Configuration prefix for overrides for the destination filesystem
CONF_SKIP_TMP - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
CONF_SOURCE_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
Configuration prefix for overrides for the source filesystem
CONFIG - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
Denotes class names that appear in user facing configuration files.
config - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
configs - Variable in class org.apache.hadoop.hbase.CompoundConfiguration
 
CONFIGURATION - Static variable in class org.apache.hadoop.hbase.HConstants
 
ConfigurationManager - Class in org.apache.hadoop.hbase.conf
Maintains the set of all the classes which would like to get notified when the Configuration is reloaded from the disk in the Online Configuration Change mechanism, which lets you update certain configuration properties on-the-fly, without having to restart the cluster.
ConfigurationManager() - Constructor for class org.apache.hadoop.hbase.conf.ConfigurationManager
 
configurationManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
Configuration manager is used to register/deregister and notify the configuration observers when the regionserver is notified that there was a change in the on disk configs.
ConfigurationObserver - Interface in org.apache.hadoop.hbase.conf
Every class that wants to observe changes in Configuration properties, must implement interface (and also, register itself with the ConfigurationManager object.
ConfigurationUtil - Class in org.apache.hadoop.hbase.util
Utilities for storing more complex collection types in Configuration instances.
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
 
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
 
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
 
configureCfRenaming(Configuration, Map<String, String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Sets a configuration property with key Import.CF_RENAME_PROP in conf that tells the mapper how to rename column families.
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.FlushPolicy
Upon construction, this method will be called with the region to be governed.
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
Upon construction, this method will be called with the region to be governed.
configureIncrementalLoad(Job, HTable) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
Deprecated.
Configure a MapReduce Job to perform an incremental load into the given table.
configureIncrementalLoad(Job, HTable) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
configureIncrementalLoad(Job, Table, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
Configure a MapReduce Job to perform an incremental load into the given table.
configureIncrementalLoad(Job, HTableDescriptor, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
Configure a MapReduce Job to perform an incremental load into the given table.
configureIncrementalLoadMap(Job, Table) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
configureInfoServer() - Method in class org.apache.hadoop.hbase.master.HMaster
 
configureInfoServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
configureJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
Job configuration.
configureJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SampleUploader
Job configuration.
configureSplitTable(Job, TableName) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Sets split table in map-reduce job.
ConfigUtil - Class in org.apache.hadoop.hbase.util
Some configuration related utilities
ConfigUtil() - Constructor for class org.apache.hadoop.hbase.util.ConfigUtil
 
confirmNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Confirm an existing unassigned node for the specified region which is currently in the OPENING state to be still in the OPENING state on the specified server.
confirmRegionMergeTransaction(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, RegionMergeCoordination.RegionMergeDetails) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
Confirm that the region merge can be performed
confirmRegionMergeTransaction(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, RegionMergeCoordination.RegionMergeDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
 
ConfServlet - Class in org.apache.hadoop.hbase.http.conf
A servlet to print out the running configuration data.
ConfServlet() - Constructor for class org.apache.hadoop.hbase.http.conf.ConfServlet
 
ConfServlet.BadFormatException - Exception in org.apache.hadoop.hbase.http.conf
 
ConfServlet.BadFormatException(String) - Constructor for exception org.apache.hadoop.hbase.http.conf.ConfServlet.BadFormatException
 
connect(HConnection) - Method in class org.apache.hadoop.hbase.client.HConnectable
 
connect(Configuration) - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
 
connect(Configuration) - Method in interface org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
 
connect() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
To repair region consistency, one must call connect() in order to repair online state.
connect(Configuration, Watcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates a new connection to ZooKeeper, pulling settings and ensemble config from the specified configuration object using methods from ZKConfig.
connect(Configuration, String, Watcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
connect(Configuration, String, Watcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
connection - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
Connection - Interface in org.apache.hadoop.hbase.client
A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
connection - Variable in class org.apache.hadoop.hbase.client.HTable
 
connection - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
connection - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
 
connection - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
connection - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
ConnectionCache - Class in org.apache.hadoop.hbase.util
A utility to store user specific HConnections in memory.
ConnectionCache(Configuration, UserProvider, int, int) - Constructor for class org.apache.hadoop.hbase.util.ConnectionCache
 
ConnectionClosingException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when the client believes that we are trying to communicate to has been repeatedly unresponsive for a while.
ConnectionClosingException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosingException
 
ConnectionConfiguration - Class in org.apache.hadoop.hbase.client
Configuration parameters for the connection.
ConnectionConfiguration() - Constructor for class org.apache.hadoop.hbase.client.ConnectionConfiguration
Constructor This is for internal testing purpose (using the default value).
ConnectionFactory - Class in org.apache.hadoop.hbase.client
A non-instantiable class that manages creation of Connections.
ConnectionFactory() - Constructor for class org.apache.hadoop.hbase.client.ConnectionFactory
No public c.tors
ConnectionId - Class in org.apache.hadoop.hbase.ipc
This class holds the address and the user ticket, etc.
ConnectionId(User, String, InetSocketAddress) - Constructor for class org.apache.hadoop.hbase.ipc.ConnectionId
 
connectionList - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
connections - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
ConnectionUtils - Class in org.apache.hadoop.hbase.client
Utility used by client connections.
ConnectionUtils() - Constructor for class org.apache.hadoop.hbase.client.ConnectionUtils
 
connectTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
Consistency - Enum in org.apache.hadoop.hbase.client
Consistency defines the expected consistency level for an operation.
consistency - Variable in class org.apache.hadoop.hbase.client.Query
 
consolidate() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
Constants - Interface in org.apache.hadoop.hbase.rest
Common constants for org.apache.hadoop.hbase.rest
ConstantSizeRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
A RegionSplitPolicy implementation which splits a region as soon as any of its store files exceeds a maximum configurable size.
ConstantSizeRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
 
constrainHttpMethods(Context, boolean) - Static method in class org.apache.hadoop.hbase.util.HttpServerUtil
Add constraints to a Jetty Context to disallow undesirable Http methods.
Constraint - Interface in org.apache.hadoop.hbase.constraint
Apply a Constraint (in traditional database terminology) to a HTable.
ConstraintException - Exception in org.apache.hadoop.hbase.constraint
Exception that a user defined constraint throws on failure of a Put.
ConstraintException() - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
 
ConstraintException(String) - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
 
ConstraintException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
 
ConstraintProcessor - Class in org.apache.hadoop.hbase.constraint
Processes multiple Constraints on a given table.
ConstraintProcessor() - Constructor for class org.apache.hadoop.hbase.constraint.ConstraintProcessor
Create the constraint processor.
Constraints - Class in org.apache.hadoop.hbase.constraint
Utilities for adding/removing constraints from a table.
constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
 
constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
 
constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
 
constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
 
constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
 
constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
 
constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
 
constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
 
constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
 
constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
 
constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
 
constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
 
constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
 
constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
 
constructMaster(Class<? extends HMaster>, Configuration, CoordinatedStateManager) - Static method in class org.apache.hadoop.hbase.master.HMaster
Utility for constructing an instance of the passed HMaster class.
constructOutputStream(DataOutput) - Static method in class org.apache.hadoop.hbase.io.DataOutputOutputStream
Construct an OutputStream from the given DataOutput.
constructRegionServer(Class<? extends HRegionServer>, Configuration, CoordinatedStateManager) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Utility for constructing an instance of the passed HRegionServer class.
consume() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
consume one available unit.
consume(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
consume amount available units, amount could be a negative number
consumeRead(long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
Removes or add back some read amount to the quota.
consumeRead(long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
 
consumerLoop(BlockingQueue<HFileCleaner.HFileDeleteTask>) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
consumeWrite(long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
Removes or add back some write amount to the quota.
consumeWrite(long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
 
contains(Object) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
contains(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
contains(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
contains(Object) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
contains(byte[], int, int, ByteBuffer) - Method in interface org.apache.hadoop.hbase.util.BloomFilter
Check if the specified key is contained in the bloom filter.
contains(Object) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
contains(byte[], int, int, ByteBuffer) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
contains(byte[], int, int, ByteBuffer, int, int, Hash, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
contains(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
contains(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
contains(byte[], int, int, ByteBuffer) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
 
contains(String) - Method in class org.apache.hadoop.hbase.util.LossyCounting
 
contains(Object) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
contains(Object) - Method in class org.apache.hadoop.hbase.util.SortedList
 
containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedList
 
containsBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Whether the cache contains block with specified cacheKey
containsColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Checks for existence of a value for the specified column (empty or not).
containsColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Checks for existence of a value for the specified column (empty or not).
containsEmptyColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Checks if the specified column contains an empty value (a zero-length byte array).
containsEmptyColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Checks if the specified column contains an empty value (a zero-length byte array).
containsIgnoreMvccVersion(Collection<? extends Cell>, Collection<? extends Cell>) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
Checks whether KeyValues from kvCollection2 are contained in kvCollection1.
containsKey(Object) - Method in class org.apache.hadoop.hbase.hbtop.Record
 
containsKey(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
containsKey(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Checks whether there is a value in the map for the specified key.
containsKey(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
containsKey(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
containsNonEmptyColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Checks if the specified column contains a non-empty value (not a zero-length byte array).
containsNonEmptyColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Checks if the specified column contains a non-empty value (not a zero-length byte array).
containsRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
Returns true if the given inclusive range of rows is fully contained by this region.
containsRow(byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
Return true if the given row falls in this region.
containsServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
containsTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
containsValue(Object) - Method in class org.apache.hadoop.hbase.hbtop.Record
 
containsValue(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
containsValue(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Checks whether this is a mapping which contains the specified value.
containsValue(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
Context - Class in org.apache.hadoop.hbase.io.crypto
Crypto context.
CONTEXT - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
control(String, long) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
 
control(String, long) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
control(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
Control the throughput.
controller - Variable in class org.apache.hadoop.hbase.client.PayloadCarryingServerCallable
 
controller - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
controller - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
controllerConnectionFailure(String, Throwable, String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
The connection to the rest of the procedure group (member and coordinator) has been broken/lost/failed.
controllerFactory - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
controlPerSize - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
convert() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
convert(ClusterStatusProtos.ClusterStatus) - Static method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
convert(HBaseProtos.ColumnFamilySchema) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
convert() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
convert(HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Convert a HRegionInfo to a RegionInfo
convert(HBaseProtos.RegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Convert a RegionInfo to a HRegionInfo
convert() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
convert(HBaseProtos.TableSchema) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
convert() - Method in class org.apache.hadoop.hbase.io.Reference
 
convert(FSProtos.Reference) - Static method in class org.apache.hadoop.hbase.io.Reference
 
convert() - Method in class org.apache.hadoop.hbase.master.RegionState
Convert a RegionState to an HBaseProtos.RegionState
convert(ClusterStatusProtos.RegionState) - Static method in class org.apache.hadoop.hbase.master.RegionState
Convert a protobuf HBaseProtos.RegionState to a RegionState
convert() - Method in enum org.apache.hadoop.hbase.master.RegionState.State
Convert to protobuf ClusterStatusProtos.RegionState.State
convert(ClusterStatusProtos.RegionState.State) - Static method in enum org.apache.hadoop.hbase.master.RegionState.State
Convert a protobuf HBaseProtos.RegionState.State to a RegionState.State
convert(Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.Procedure
Helper to convert the procedure to protobuf.
convert(ProcedureProtos.Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.Procedure
Helper to convert the protobuf procedure.
convert() - Method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
 
convert() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
convert(ProcedureProtos.ProcedureStoreTracker.TrackerNode) - Static method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
convert(ProcedureProtos.Procedure) - Static method in class org.apache.hadoop.hbase.ProcedureInfo
Deprecated.
convert(Map<TableName, ? extends Collection<String>>) - Static method in class org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
convert map to TableCFs Object
convert(String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
Convert string to TableCFs Object.
convert(ZooKeeperProtos.TableCF[]) - Static method in class org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
Convert TableCFs Object to String.
convert(DeserializationException) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Convert a DeserializationException to a more palatable KeeperException.
convert2Map(ZooKeeperProtos.TableCF[]) - Static method in class org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
Convert tableCFs Object to Map.
convertByteArrayToBoolean(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Converts a boolean expressed in a byte array to an actual boolean
convertByteArrayToInt(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Converts an int expressed in a byte array to an actual int
convertByteArrayToLong(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Converts a long expressed in a byte array to an actual long
convertResult(MasterProtos.GetProcedureResultResponse) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Convert the procedure result response to a specified type.
convertScanToString(Scan) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Writes the given scan into a Base64 encoded string.
convertStringToScan(String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Converts the given Base64 string back into a Scan instance.
convertThrowableToIOE(Throwable, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
convertToBigInteger(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
Returns the BigInteger represented by the byte array
convertToByte(BigInteger, int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
Returns the bytes corresponding to the BigInteger
convertToByte(BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
Returns the bytes corresponding to the BigInteger
convertToBytes(BigInteger[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
Returns an array of bytes corresponding to an array of BigIntegers
convertToProcedureProto(ProcedureInfo) - Static method in class org.apache.hadoop.hbase.ProcedureInfo
Deprecated.
convertToString(Map<TableName, ? extends Collection<String>>) - Static method in class org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
 
CoordinatedStateException - Exception in org.apache.hadoop.hbase
Thrown by operations requiring coordination state access or manipulation when internal error within coordination engine (or other internal implementation) occurs.
CoordinatedStateException() - Constructor for exception org.apache.hadoop.hbase.CoordinatedStateException
 
CoordinatedStateException(String) - Constructor for exception org.apache.hadoop.hbase.CoordinatedStateException
 
CoordinatedStateException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.CoordinatedStateException
 
CoordinatedStateException(Throwable) - Constructor for exception org.apache.hadoop.hbase.CoordinatedStateException
 
CoordinatedStateManager - Interface in org.apache.hadoop.hbase
Implementations of this interface will keep and return to clients implementations of classes providing API to execute coordinated operations.
CoordinatedStateManagerFactory - Class in org.apache.hadoop.hbase
Creates instance of CoordinatedStateManager based on configuration.
CoordinatedStateManagerFactory() - Constructor for class org.apache.hadoop.hbase.CoordinatedStateManagerFactory
 
coordinator - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
 
COPROC - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
 
Coprocessor - Interface in org.apache.hadoop.hbase
Coprocessor interface.
Coprocessor.State - Enum in org.apache.hadoop.hbase
Lifecycle state of a given coprocessor instance.
COPROCESSOR_EXECUTION_STATISTICS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
COPROCESSOR_EXECUTION_STATISTICS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
CoprocessorClassLoader - Class in org.apache.hadoop.hbase.util
ClassLoader used to load classes for Coprocessor instances.
CoprocessorEnvironment - Interface in org.apache.hadoop.hbase
Coprocessor environment state.
CoprocessorException - Exception in org.apache.hadoop.hbase.coprocessor
Thrown if a coprocessor encounters any exception.
CoprocessorException() - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
Default Constructor
CoprocessorException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
Constructor with a Class object and exception message.
CoprocessorException(String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
Constructs the exception and supplies a string as the message
CoprocessorHConnection - Class in org.apache.hadoop.hbase.client
Connection to an HTable from within a Coprocessor.
CoprocessorHConnection(ClusterConnection, HRegionServer) - Constructor for class org.apache.hadoop.hbase.client.CoprocessorHConnection
Deprecated.
delegate is not used
CoprocessorHConnection(HRegionServer) - Constructor for class org.apache.hadoop.hbase.client.CoprocessorHConnection
Constructor that uses server configuration
CoprocessorHConnection(Configuration, HRegionServer) - Constructor for class org.apache.hadoop.hbase.client.CoprocessorHConnection
Constructor that accepts custom configuration
CoprocessorHost<E extends CoprocessorEnvironment> - Class in org.apache.hadoop.hbase.coprocessor
Provides the common setup framework and runtime services for coprocessor invocation from HBase services.
CoprocessorHost(Abortable) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
CoprocessorHost.Environment - Class in org.apache.hadoop.hbase.coprocessor
Encapsulation of the environment of each coprocessor
CoprocessorHost.Environment(Coprocessor, int, int, Configuration) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
Constructor
CoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
Base class which provides clients with an RPC connection to call coprocessor endpoint Services.
CoprocessorRpcChannel() - Constructor for class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
CoprocessorRpcUtils - Class in org.apache.hadoop.hbase.ipc
Utilities for handling coprocessor service calls.
coprocessors - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Ordered set of loaded coprocessors with lock
COPROCESSORS_ENABLED_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
coprocessorService() - Method in interface org.apache.hadoop.hbase.client.Admin
Creates and returns a RpcChannel instance connected to the active master.
coprocessorService(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates and returns a RpcChannel instance connected to the passed region server.
coprocessorService() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates and returns a RpcChannel instance connected to the active master.
coprocessorService(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates and returns a RpcChannel instance connected to the passed region server.
coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Creates and returns a RpcChannel instance connected to the table region containing the specified row.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.client.HTable
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
coprocessorService(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
Creates and returns a RpcChannel instance connected to the table region containing the specified row.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
CoprocessorService - Interface in org.apache.hadoop.hbase.coprocessor
Coprocessor endpoints providing protobuf services should implement this interface and return the Service instance via CoprocessorService.getService().
coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
copy(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Copy the byte array given in parameter and return an instance of a new byte array with the same length and the same content.
copy(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Copy the byte array given in parameter and return an instance of a new byte array with the same length and the same content.
copy(byte[], int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
Copies the bytes from given array's offset to length part into the given buffer.
copy(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
Copies specified number of bytes from given offset of src ByteBuffer to the dest array.
copy(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
Copies specified number of bytes from given offset of src buffer into the dest buffer.
copyBufferToNewArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
 
copyBufferToStream(OutputStream, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copy data from a buffer to an output stream.
copyBytes() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Returns a copy of the bytes referred to by this writable
copyBytes() - Method in class org.apache.hadoop.hbase.util.Bytes
Returns a copy of the bytes referred to by this writable
copyDeadServersSince(long) - Method in class org.apache.hadoop.hbase.master.DeadServer
Extract all the servers dead since a given time, and sort them.
copyFamilyTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
copyFrom(Result) - Method in class org.apache.hadoop.hbase.client.Result
Copy another Result into this one.
copyFromBufferToArray(byte[], ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copies specified number of bytes from given offset of 'in' ByteBuffer to the array.
copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copy from one buffer to another from given offset.
copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copy from one buffer to another from given offset.
copyFromNext(BufferedDataBlockEncoder.SeekerState) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffSeekerState
 
copyFromNext(BufferedDataBlockEncoder.SeekerState) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffSeekerState
 
copyFromNext(RowIndexSeekerV1.SeekerState) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
Copy the state from the next one into this instance (the previous state placeholder).
copyFromStreamToBuffer(ByteBuffer, DataInputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copy the given number of bytes from the given stream and put it at the current position of the given buffer, updating the position in the buffer.
CopyKeyDataBlockEncoder - Class in org.apache.hadoop.hbase.io.encoding
Just copy data, do not do any kind of compression.
CopyKeyDataBlockEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
copyKeyToNewByteBuffer(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
The position will be set to the beginning of the new ByteBuffer
COPYONWRITE_ARRAYLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for CopyOnWriteArrayList
COPYONWRITE_ARRAYSET - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for CopyOnWriteArraySet
CopyOnWriteArrayMap<K,V> - Class in org.apache.hadoop.hbase.types
A Map that keeps a sorted array in order to provide the concurrent map interface.
CopyOnWriteArrayMap() - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
CopyOnWriteArrayMap(Comparator<? super K>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
copyQualifierTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
copyRowTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
copyTo
copyServerNames() - Method in class org.apache.hadoop.hbase.master.DeadServer
 
copySnapshotForScanner(Configuration, FileSystem, Path, Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
Copy the snapshot files for a snapshot scanner, discards meta changes.
CopyTable - Class in org.apache.hadoop.hbase.mapreduce
Tool used to copy a table to another one which can be on a different setup.
CopyTable(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.CopyTable
 
copyTagTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
Copies the tags info into the tag portion of the cell
copyToNewArrays(Collection<ByteRange>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
 
copyToNewByteArray(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
copyToNewByteBuffer(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
The position will be set to the beginning of the new ByteBuffer
copyToNewKeyValue(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
copy key only
copyValueTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
copyWritable(Writable, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
Copy one Writable to another.
copyWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
Copy one Writable to another.
CORRUPT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
CorruptedSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
Exception thrown when the found snapshot info from the filesystem is not valid.
CorruptedSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
Snapshot was corrupt for some reason.
CorruptedSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
Deprecated.
since 1.3.0, will be removed in 3.0.0
CorruptedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
Snapshot was corrupt for some reason.
CorruptedWALProcedureStoreException - Exception in org.apache.hadoop.hbase.procedure2.store.wal
Thrown when a procedure WAL is corrupted
CorruptedWALProcedureStoreException() - Constructor for exception org.apache.hadoop.hbase.procedure2.store.wal.CorruptedWALProcedureStoreException
default constructor
CorruptedWALProcedureStoreException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.store.wal.CorruptedWALProcedureStoreException
Constructor
CorruptHFileException - Exception in org.apache.hadoop.hbase.io.hfile
This exception is thrown when attempts to read an HFile fail due to corruption or truncation issues.
CorruptHFileException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.io.hfile.CorruptHFileException
 
CorruptHFileException(String) - Constructor for exception org.apache.hadoop.hbase.io.hfile.CorruptHFileException
 
COUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
COUNT_OF_ROWS_FILTERED_KEY - Static variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
COUNT_OF_ROWS_FILTERED_KEY_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
COUNT_OF_ROWS_SCANNED_KEY - Static variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
COUNT_OF_ROWS_SCANNED_KEY_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
countDown(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.CompatibilityLatch
 
countDown(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
 
Counter - Interface in org.apache.hadoop.hbase.metrics
A mutable number optimized for high concurrency counting.
counter(String) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
counter(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
Get or construct a Counter used to track a mutable number.
Counter - Class in org.apache.hadoop.hbase.util
High scalable counter.
Counter() - Constructor for class org.apache.hadoop.hbase.util.Counter
 
Counter(long) - Constructor for class org.apache.hadoop.hbase.util.Counter
 
CounterImpl - Class in org.apache.hadoop.hbase.metrics.impl
Custom implementation of Counter using LongAdder.
CounterImpl() - Constructor for class org.apache.hadoop.hbase.metrics.impl.CounterImpl
 
countOfBytesInRemoteResults - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of bytes in Result objects from remote region servers
countOfBytesInResults - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of bytes in Result objects from region servers
countOfNSRE - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of NotServingRegionException caught
countOfRegions - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of regions
countOfRegionServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
 
countOfRemoteRPCcalls - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of remote RPC calls
countOfRemoteRPCRetries - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of remote RPC retries
countOfRowsFiltered - Variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
number of rows filtered during scan RPC
countOfRowsScanned - Variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
number of rows scanned during scan RPC.
countOfRPCcalls - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of RPC calls
countOfRPCRetries - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
number of RPC retries
countPerRow - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
CP_HTD_ATTR_INCLUSION_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
CP_HTD_ATTR_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
 
CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
 
CP_HTD_ATTR_VALUE_PARAM_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
 
CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
 
CP_HTD_ATTR_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
Pattern that matches a coprocessor specification.
create(Configuration) - Static method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
Create an archive tracker for the passed in server
create(Configuration) - Static method in class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory
 
create(List<Cell>) - Static method in class org.apache.hadoop.hbase.client.Result
Instantiate a Result with the specified List of KeyValues.
create(List<Cell>, Boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(List<Cell>, Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(List<Cell>, Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(Cell[]) - Static method in class org.apache.hadoop.hbase.client.Result
Instantiate a Result with the specified array of KeyValues.
create(Cell[], Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(Cell[], Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(Configuration) - Static method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
 
create() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Creates a Configuration with HBase resources
create(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
 
create() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
create(Configuration, FileSystem, Path, HRegionInfo, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink
create(Configuration, FileSystem, Path, HRegionInfo, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink
create(Configuration, FileSystem, Path, TableName, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink
create(Configuration, FileSystem, Path, TableName, String, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink
create(String, MetricsHBaseServerWrapper) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl
 
create(DataInput) - Static method in class org.apache.hadoop.hbase.KeyValue
 
create(int, DataInput) - Static method in class org.apache.hadoop.hbase.KeyValue
Create a KeyValue reading length from in
create(String, String, String, long, String) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
create(String, String, String, long, KeyValue.Type, String) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
 
create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, String) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
Deprecated.
create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, List<Tag>) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
 
create(MetricsMasterWrapper) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactory
 
create(MetricsMasterWrapper) - Method in class org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactoryImpl
 
create(MetricsMasterWrapper) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSourceFactory
 
create(MetricsMasterWrapper) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl
 
create(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
 
create(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryFactoryImpl
 
create(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
Create or return MetricRegistry with the given info.
create(MetricRegistryInfo) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistryFactory
Create a MetricRegistry from the given MetricRegistryInfo
create(String) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
 
create(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
 
create(Configuration, PriorityFunction, Abortable) - Method in class org.apache.hadoop.hbase.regionserver.FifoRpcSchedulerFactory
 
create(Configuration, PriorityFunction) - Method in class org.apache.hadoop.hbase.regionserver.FifoRpcSchedulerFactory
Deprecated.
create(HRegion, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
Create the FlushPolicy configured for the given table.
create(Configuration, FlushRequester, Server, RegionServerAccounting) - Static method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
create(ScanInfo, ScanType, long, long, long, long, byte[], byte[], RegionCoprocessorHost) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
create(Scan, ScanInfo, NavigableSet<byte[]>, ScanType, long, long, long, long, byte[], byte[], RegionCoprocessorHost) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.LegacyScanQueryMatcher
Deprecated.
 
create(Scan, ScanInfo, ColumnTracker, boolean, long, long, RegionCoprocessorHost) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
 
create(Scan, ScanInfo, ColumnTracker, boolean, long, long) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
 
create(Scan, ScanInfo, NavigableSet<byte[]>, long, long, RegionCoprocessorHost) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
create(Region, Region, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionFactory
Create a merge transaction
create(HRegion, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
Create the RegionSplitPolicy configured for the given table.
create(Configuration, PriorityFunction, Abortable) - Method in interface org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory
Constructs a RpcScheduler.
create(Configuration, PriorityFunction) - Method in interface org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory
Deprecated.
since 1.0.0.
create(Configuration, PriorityFunction) - Method in class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
Deprecated.
since 1.0.0.
create(Configuration, PriorityFunction, Abortable) - Method in class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
 
create(Region, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
Create a split transaction
create(Store, Configuration, KeyValue.KVComparator) - Static method in class org.apache.hadoop.hbase.regionserver.StoreEngine
Create the StoreEngine configured for the given Store.
create(RegionServerServices, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.CompactionThroughputControllerFactory
 
create(RegionServerServices, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.FlushThroughputControllerFactory
 
create(Configuration, String, CompressionContext) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
Create and setup a WALCellCodec from the cellCodecClsName and CompressionContext, if cellCodecClsName is specified.
create(Configuration, CompressionContext) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
Create and setup a WALCellCodec from the CompressionContext.
create(UserGroupInformation) - Static method in class org.apache.hadoop.hbase.security.User
Wraps an underlying UserGroupInformation instance.
create(UserGroupInformation) - Method in class org.apache.hadoop.hbase.security.UserProvider
Wraps an underlying UserGroupInformation instance.
create(Configuration, FileSystem, Path, HBaseProtos.SnapshotDescription, ForeignExceptionSnare) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Return a SnapshotManifest instance, used for writing a snapshot.
create(Configuration, FileSystem, Path, FsPermission, InetSocketAddress[]) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Create the specified file on the filesystem.
create(FileSystem, Path, FsPermission, boolean) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Create the specified file on the filesystem.
create() - Method in class org.apache.hadoop.hbase.util.RetryCounterFactory
 
create(A, B, C) - Static method in class org.apache.hadoop.hbase.util.Triple
 
create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
NONSEQUENTIAL create is idempotent operation.
CREATE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
CREATE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
createACL(ZooKeeperWatcher, String, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
createAndAddPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
Attempt to connect to a new remote slave cluster.
createAndFailSilent(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node, iff the node does not exist.
createAndFailSilent(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node containing specified data, iff the node does not exist.
createAndFailSilent(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
 
createAndGet(ZooKeeperWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
Creates the singleton instance, if not yet present, and returns the same.
createAndPrepare(T, ObserverContext<T>) - Static method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
Instantiates a new ObserverContext instance if the passed reference is null and sets the environment in the new or existing instance.
createAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node with the specified data and watches it.
createAnother() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
Creates another similar Bloom filter.
createBaseListener(Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer
Create a required listener for the Jetty instance listening on the port provided.
createBlockingRpcChannel(ServerName, User, int) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
createBlockingRpcChannel(ServerName, User, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
Creates a "channel" that can be used by a blocking protobuf service.
createBloomKey(byte[], int, int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
Create a key for a row-column Bloom filter.
createBloomKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
Create a key for a row-column Bloom filter.
createBloomKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
Prepare an ordered pair of row and qualifier to be compared using KeyValue.KeyComparator.
createBottomReference(byte[]) - Static method in class org.apache.hadoop.hbase.io.Reference
 
createBulkLoadEvent(HRegionInfo, WALProtos.BulkLoadDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
Create a bulk loader WALEdit
createBySize(int, double, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
Creates a Bloom filter of the given size.
createCell(byte[], byte[], byte[], long, byte, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
 
createCell(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
createCell(byte[], byte[], byte[], long, byte, byte[], long) - Static method in class org.apache.hadoop.hbase.CellUtil
Marked as audience Private as of 1.2.0.
createCell(byte[], byte[], byte[], long, byte, byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.CellUtil
Marked as audience Private as of 1.2.0.
createCell(byte[], byte[], byte[], long, KeyValue.Type, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Marked as audience Private as of 1.2.0.
createCell(byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Create a Cell with specific row.
createCell(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Create a Cell with specific row and value.
createCell(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Create a Cell with specific row.
createCellScanner(List<? extends CellScannable>) - Static method in class org.apache.hadoop.hbase.CellUtil
 
createCellScanner(Iterable<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
 
createCellScanner(Iterator<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
 
createCellScanner(Cell[]) - Static method in class org.apache.hadoop.hbase.CellUtil
 
createCellScanner(NavigableMap<byte[], List<Cell>>) - Static method in class org.apache.hadoop.hbase.CellUtil
Flatten the map of cells out under the CellScanner
createCleanupScheduledChore(Stoppable) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
Creates a scheduled chore that is used to clean up old nonces.
createClient(Configuration, String) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
Helper method for tests only.
createClient(Configuration, String, MetricsConnection) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
Creates a new RpcClient by the class defined in the configuration or falls back to RpcClientImpl
createClient(Configuration, String, SocketAddress, MetricsConnection) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
Creates a new RpcClient by the class defined in the configuration or falls back to RpcClientImpl
createCluster(List<ServerName>, Collection<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
createClusterConf(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Generates a Configuration instance by applying the ZooKeeper cluster key to the base Configuration.
createClusterConf(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Generates a Configuration instance by applying property overrides prefixed by a cluster profile key to the base Configuration.
createClusterConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Create a 'smarter' HConnection, one that is capable of by-passing RPC if the request is to the local server.
createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine
 
createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
Creates an instance of a compaction context specific to this engine.
createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
 
createCompaction(HRegionInfo, WALProtos.CompactionDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
Create a compaction WALEdit
createCompactionRequest(ArrayList<StoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
 
createCompactionRequest(ArrayList<StoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
 
createCompactionRequest(ArrayList<StoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
 
createComparator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Parses a comparator of the form comparatorType:comparatorValue form and returns a comparator
createComparator(String) - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
createCompareOp(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Takes a compareOperator symbol as a byte array and returns the corresponding CompareOperator
createCompleteResult(List<Result>) - Static method in class org.apache.hadoop.hbase.client.Result
Deprecated. 
createCompleteResult(Iterable<Result>) - Static method in class org.apache.hadoop.hbase.client.Result
Forms a single result from the partial results in the partialResults list.
createComponents(Configuration, Store, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine
 
createComponents(Configuration, Store, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
createComponents(Configuration, Store, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
Create the StoreEngine's components.
createComponents(Configuration, Store, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
 
createCompressionStream(OutputStream, Compressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
createConnection() - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using default HBaseConfiguration.
createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
createConnection(Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
createConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
createConnection(Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
createConnection(ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Not connected.
createConnection(ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcClient
Creates a connection.
createConnection(ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcClient
 
createContextName(String) - Static method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory
From the name of the class that's starting up create the context that an IPC source should register itself.
createCounter(String) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
Create a new counter with the specified name
createCounter() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
createCursor(byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientUtil
 
createCursorResult(Cursor) - Static method in class org.apache.hadoop.hbase.client.Result
 
createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
createDecryptionStream(InputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
createDecryptionStream(InputStream, Decryptor) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
createDecryptionStream(InputStream) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
 
createDecryptionStream(InputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create a decrypting input stream given a context and IV
createDecryptionStream(InputStream, Decryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create a decrypting output stream given an initialized decryptor
createDecryptionStream(InputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
Create a stream for decryption
createDefaultChannelConnector() - Static method in class org.apache.hadoop.hbase.http.HttpServer
 
createDeleteBloomAtWrite(Configuration, CacheConfig, int, HFile.Writer) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
Creates a new Delete Family Bloom filter at the time of StoreFile writing.
createDestinationServersList(List<ServerName>) - Method in class org.apache.hadoop.hbase.master.ServerManager
Creates a list of possible destinations for a region.
createDestinationServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
createDigestSaslClient(String[], String, CallbackHandler) - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
createDirectory(MasterProcedureEnv, NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
Create the namespace directory
createEmptyRequest(StripeCompactionPolicy.StripeInformationProvider, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
 
createEncoder(String) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
createEncryptionStream(OutputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
createEncryptionStream(OutputStream, Encryptor) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
createEncryptionStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
 
createEncryptionStream(OutputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create an encrypting output stream given a context and IV
createEncryptionStream(OutputStream, Encryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create an encrypting output stream given an initialized encryptor
createEncryptionStream(OutputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Create a stream for encryption
createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Called when a new Coprocessor class is loaded
createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
 
createEphemeralNodeAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Set the specified znode to be an ephemeral node carrying the specified data.
createEventLoopPerClient(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
The AsyncRpcClient will create its own NioEventLoopGroup.
createExceptionString(Class) - Static method in class org.apache.hadoop.hbase.CompatibilityFactory
 
createExecutor(Configuration, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
createFileScanners(Collection<StoreFile>, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
Creates file scanners for compaction.
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FilterBase
Given the filter's arguments it constructs the filter
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
 
createFirstDeleteFamilyOnRow(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a Delete Family KeyValue for the specified row and family that would be smaller than all other possible Delete Family KeyValues that have the same row and family.
createFirstKeyInIncrementedRow(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Increment the row bytes and clear the other fields
createFirstKeyInNextRow(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Append single byte 0x00 to the end of the input row key
createFirstOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
Deprecated.
Since 0.99.2. Use KeyValueUtil.createFirstOnRow(byte []) instead
createFirstOnRow(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
Deprecated.
createFirstOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
createFirstOnRow(byte[], int, short) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue that is smaller than all other possible KeyValues for the given row.
createFirstOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue that is smaller than all other possible KeyValues for the given row.
createFirstOnRow(byte[], long) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Creates a KeyValue that is smaller than all other KeyValues that are older than the passed timestamp.
createFirstOnRow(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row,family,qualifier.
createFirstOnRow(byte[], byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
createFirstOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row, family, qualifier.
createFirstOnRow(byte[], byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row, family, qualifier.
createFirstOnRow(byte[], int, byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row, family, qualifier.
createFirstOnRowColTS(Cell, long) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Creates the first KV with the row/family/qualifier of this KV and the given timestamp.
createFirstOnRowColTS(KeyValue, long) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Creates the first KV with the row/family/qualifier of this KV and the given timestamp.
createFlushContext(long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
createFlushContext(long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
createFlushWALEdit(HRegionInfo, WALProtos.FlushDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
createFromFileInfo(HFile.FileInfo) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
createFromHFileLink(Configuration, FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink starting from a hfileLink name
createFromHFileLink(Configuration, FileSystem, Path, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink starting from a hfileLink name
createFromMeta(DataInput, HFile.Reader) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
Instantiates the correct Bloom filter class based on the version provided in the meta block data.
createFsLayout(MasterProcedureEnv, HTableDescriptor, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
createFsLayout(MasterProcedureEnv, HTableDescriptor, List<HRegionInfo>, CreateTableProcedure.CreateHdfsRegions) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
createGeneralBloomAtWrite(Configuration, CacheConfig, BloomType, int, HFile.Writer) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
Creates a new general (Row or RowCol) Bloom filter at the time of StoreFile writing.
createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Create a key by concatenating multiple column values.
createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Create a key by concatenating multiple column values.
createGson() - Static method in class org.apache.hadoop.hbase.util.GsonUtil
Create a builder which is used to create a Gson instance.
createHDFSRegionDir(Configuration, HRegionInfo, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
Creates, flushes, and closes a new region.
createHdfsRegions(MasterProcedureEnv, Path, TableName, List<HRegionInfo>) - Method in interface org.apache.hadoop.hbase.master.procedure.CreateTableProcedure.CreateHdfsRegions
 
createHFileContext(FSDataInputStreamWrapper, long, HFileSystem, Path, FixedFileTrailer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
createHFileContext(FSDataInputStreamWrapper, long, HFileSystem, Path, FixedFileTrailer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
 
createHFileCorruptionChecker(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
createHFileLinkName(HRegionInfo, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink name
createHFileLinkName(TableName, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink name
createHistogram() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
createHostAndPortStr(String, int) - Static method in class org.apache.hadoop.hbase.util.Addressing
 
createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Convenience method creating new HRegions.
createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, WAL, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Convenience method creating new HRegions.
createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, WAL, boolean, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Convenience method creating new HRegions.
createHRegion(HRegionInfo, Path, Path, Configuration, HTableDescriptor, WAL, boolean, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Convenience method creating new HRegions.
createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, WAL) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
 
createHRegionInfos(HTableDescriptor, byte[][]) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
 
createHTable(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
 
createHTableInterface(Configuration, byte[]) - Method in class org.apache.hadoop.hbase.client.HTableFactory
Deprecated.
 
createHTableInterface(Configuration, byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
Deprecated.
Creates a new HTableInterface.
createIdentifier() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
createInetSocketAddressFromHostAndPortStr(String) - Static method in class org.apache.hadoop.hbase.util.Addressing
 
createIO(MetricsIOWrapper) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
Create a MetricsIOSource from a MetricsIOWrapper.
createIO(MetricsIOWrapper) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
 
createKerberosSaslClient(String[], String, String) - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
createKeyOnly(boolean) - Method in class org.apache.hadoop.hbase.KeyValue
Creates a new KeyValue that only contains the key portion (the value is set to be null).
createKeyValueFromKey(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
 
createKeyValueFromKey(ByteBuffer) - Static method in class org.apache.hadoop.hbase.KeyValue
 
createKeyValueFromKey(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
 
createKVBuffer() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
createLastOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue for the specified row, family and qualifier that would be larger than or equal to all other possible KeyValues that have the same row, family, qualifier.
createLastOnRow(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Creates a keyValue for the specified keyvalue larger than or equal to all other possible KeyValues that have the same row, family, qualifer.
createLastOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Creates a KeyValue that is last on the specified row id.
createLastOnRowCol(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Similar to KeyValueUtil.createLastOnRow(byte[], int, int, byte[], int, int, byte[], int, int) but creates the last key on the row/column of this KV (the value part of the returned KV is always empty).
createLatch() - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
 
createLease(String, int, LeaseListener) - Method in class org.apache.hadoop.hbase.regionserver.Leases
Create a lease and insert it to the map of leases.
createMasterThread(Configuration, CoordinatedStateManager, Class<? extends HMaster>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
createMaxByteArray(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Create a max byte array with the specified max byte count
createMeter() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new namespace
createNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create a new namespace
createNamespace(NamespaceDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
createNamespace(RpcController, MasterProtos.CreateNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
createNamespace(NamespaceDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Create a new namespace
CreateNamespaceProcedure - Class in org.apache.hadoop.hbase.master.procedure
The procedure to create a new namespace.
CreateNamespaceProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
CreateNamespaceProcedure(MasterProcedureEnv, NamespaceDescriptor) - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
createNamespaceSync(NamespaceDescriptor, long, long, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
createNamespaceSync(NamespaceDescriptor, long, long, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Create a new namespace synchronously.
createNInputSplitsUniform(InputSplit, int) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Create n splits for one InputSplit, For now only support uniform distribution
createNodeClosing(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Creates a new unassigned node in the CLOSING state for the specified region.
createNodeIfNotExistsAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified znode to be a persistent node carrying the specified data.
createNodeIfNotExistsNoWatch(ZooKeeperWatcher, String, byte[], CreateMode) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified znode with the specified data but does not watch it.
createNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Creates a new unassigned node in the OFFLINE state for the specified region.
createNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName, EventType) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
 
createNonceKey(long, long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Create a NoneKey from the specified nonceGroup and nonce.
createNonRecursive(Path, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.hbase.fs.HFileSystem
The org.apache.hadoop.fs.FilterFileSystem does not yet support createNonRecursive.
createObject(K) - Method in interface org.apache.hadoop.hbase.util.WeakObjectPool.ObjectFactory
Creates a new shared object associated with the given key, identified by the equals method.
createOrForceNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Creates or force updates an unassigned node to the OFFLINE state for the specified region.
createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec
 
createOutputStream(Configuration, FileSystem, Path, InetSocketAddress[]) - Static method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
A helper method to create HFile output streams in constructors
createPassword(AuthenticationTokenIdentifier) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
createPath(TableName, String, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create an HFileLink relative path for the table/region/family/hfile location
createPlainCompressionStream(OutputStream, Compressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
Creates a compression stream without any additional wrapping into buffering streams.
createPool() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
createPriority() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
createPriority() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
createProcedureInfo(Procedure, NonceKey) - Static method in class org.apache.hadoop.hbase.procedure2.Procedure
Helper to create the ProcedureInfo from Procedure.
createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.NamespacesModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.RowModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
 
createProtobufOutput() - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
 
createReader(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
The sockets and the file descriptors held by the method parameter FSDataInputStreamWrapper passed will be freed after its usage so caller needs to ensure that no other threads have access to the same passed reference.
createReader(FileSystem, Path, CacheConfig, Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
createReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
createReader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
createReader(FileSystem, Path) - Method in class org.apache.hadoop.hbase.wal.WALFactory
 
createReader(FileSystem, Path, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALFactory
Create a reader for the WAL.
createReader(FileSystem, Path, CancelableProgressable, boolean) - Method in class org.apache.hadoop.hbase.wal.WALFactory
 
createReader(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
Create a reader for the given path, accept custom reader classes from conf.
createReaderIgnoreCustomClass(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
Create a reader for the given path, ignore custom reader classes from conf.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
Deprecated.
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Builds a TableRecordReader.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
createRecoveredEditsWriter(FileSystem, Path) - Method in class org.apache.hadoop.hbase.wal.WALFactory
should be package-private, visible for recovery testing.
createRegion(MetricsRegionWrapper) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
Create a MetricsRegionSource from a MetricsRegionWrapper.
createRegion(MetricsRegionWrapper) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
 
createRegion(Configuration, Path, Path, HTableDescriptor, HRegionInfo, ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
Create new set of regions on the specified file-system.
createRegionEventWALEdit(HRegionInfo, WALProtos.RegionEventDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
createRegionLoad(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
createRegionName(TableName, byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], long, int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], byte[], int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionOnFileSystem(Configuration, FileSystem, Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Create a new Region on file-system.
createRegions(Configuration, Path, HTableDescriptor, HRegionInfo[]) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
Create new set of regions on the specified file-system.
createRegions(Configuration, Path, HTableDescriptor, HRegionInfo[], ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
Create new set of regions on the specified file-system.
createRegions(Configuration, Path, Path, HTableDescriptor, HRegionInfo[], ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
Create new set of regions on the specified file-system.
createRegions(ThreadPoolExecutor, Configuration, Path, Path, HTableDescriptor, HRegionInfo[], ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
Create new set of regions on the specified file-system.
createRegionServerStatusStub() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Get the current master from ZooKeeper and open the RPC connection to it.
createRegionServerStatusStub(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Get the current master from ZooKeeper and open the RPC connection to it.
createRegionServerThread(Configuration, CoordinatedStateManager, Class<? extends HRegionServer>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
createRegionState(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
Add a region to RegionStates.
createRegionState(HRegionInfo, RegionState.State, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
Add a region to RegionStates with the specified state.
createRegionStates(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.RegionStates
Add a list of regions to RegionStates.
createRegionTransition(EventType, byte[], ServerName) - Static method in class org.apache.hadoop.hbase.RegionTransition
 
createRegionTransition(EventType, byte[], ServerName, byte[]) - Static method in class org.apache.hadoop.hbase.RegionTransition
 
createRegistryForMasterCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
createRegistryForRegionCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
createRegistryForRSCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
createRegistryForWALCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
createRegistryInfoForRegionCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
createRegistryInfoForWALCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
createReplicator(List<WAL.Entry>, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
 
createRpcChannel(ServerName, User, int) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
createRpcChannel(ServerName, User, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
Creates a "channel" that can be used by a protobuf service.
createRpcServices() - Method in class org.apache.hadoop.hbase.master.HMaster
 
createRpcServices() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
createRPCStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
createScanFromConfiguration(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Sets up a Scan instance, applying settings from the configuration property constants defined in TableInputFormat.
createScanFromCursor(Cursor) - Static method in class org.apache.hadoop.hbase.client.Scan
Create a new Scan with a cursor.
createScanner(Store, List<StoreFileScanner>, ScanType, long, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
createScanner(Store, List<StoreFileScanner>, long, long, byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
createScanner(List<StoreFileScanner>, ScanType, Compactor.FileDetails, long) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.Compactor.InternalScannerFactory
 
createScannerCallable() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Will be called in moveToNextRegion to create ScannerCallable.
createScannerCallable() - Method in class org.apache.hadoop.hbase.client.ClientSimpleScanner
 
createScannerCallable() - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
 
createScanResultCache(Scan, List<Result>) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
 
createSecretKey(byte[]) - Static method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
createSeeker(KeyValue.KVComparator, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
Deprecated.
Is this the correct handling of an illegal comparator? How to prevent that from getting all the way to this point.
createSeeker(KeyValue.KVComparator, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
createSeeker(KeyValue.KVComparator, HFileBlockDecodingContext) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Create a HFileBlock seeker which find KeyValues within a block.
createSeeker(KeyValue.KVComparator, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
 
createSeeker(KeyValue.KVComparator, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
 
createSeeker(KeyValue.KVComparator, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
 
createSeeker(KeyValue.KVComparator, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
 
createServer(MetricsRegionServerWrapper) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
Given a wrapper create a MetricsRegionServerSource.
createServer(MetricsRegionServerWrapper) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
 
createServerSocket(int) - Method in class org.apache.hadoop.hbase.SslRMIServerSocketFactorySecure
 
createSetData(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Set data into node creating node if it doesn't yet exist.
createShortCircuitConnection(Configuration, ExecutorService, User, ServerName, AdminProtos.AdminService.BlockingInterface, ClientProtos.ClientService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Creates a short-circuit connection that can bypass the RPC layer (serialization, deserialization, networking, etc..) when talking to a local server.
createShortCircuitHConnection(Connection, ServerName, AdminProtos.AdminService.BlockingInterface, ClientProtos.ClientService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Deprecated.
CreateSnapshot - Class in org.apache.hadoop.hbase.snapshot
This is a command line class that will snapshot a given table.
CreateSnapshot() - Constructor for class org.apache.hadoop.hbase.snapshot.CreateSnapshot
 
createSocket(String, int) - Method in class org.apache.hadoop.hbase.SslRMIClientSocketFactorySecure
 
createSSLEngine() - Method in class org.apache.hadoop.hbase.jetty.SslSelectChannelConnectorSecure
 
createStartKeyFromRow(byte[], ScanInfo) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
createStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
 
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
Sets up the actual job.
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Export
Sets up the actual job.
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable
 
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
Sets up the actual job.
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable
 
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
Sets up the actual job.
createSubprocedure(String, byte[]) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
This is separated from execution so that we can detect and handle the case where the subprocedure is invalid and inactionable due to bad info (like DISABLED snapshot type being sent here)
createSystemTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
 
createSystemTable(HTableDescriptor) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Create a system table using the given table definition.
createTable(HTableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table.
createTable(HTableDescriptor, byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table with the specified number of regions.
createTable(HTableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table with an initial set of empty regions defined by the specified split keys.
createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table.
createTable(HTableDescriptor, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table with the specified number of regions.
createTable(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table with an initial set of empty regions defined by the specified split keys.
createTable(HTableDescriptor, byte[][], long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
createTable(RpcController, MasterProtos.CreateTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
createTable(HTableDescriptor, byte[][], long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Create a table using the given table definition.
createTable(String, MetricsTableWrapperAggregate) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
Create a MetricsTableSource from a MetricsTableWrapper.
createTable(String, MetricsTableWrapperAggregate) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
 
createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
Creates a new table.
createTable(ByteBuffer, List<ColumnDescriptor>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
createTable(ByteBuffer, List<ColumnDescriptor>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
createTable(ByteBuffer, List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
createTable(ByteBuffer, List<ColumnDescriptor>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Create a table with the specified column families.
createTable(ByteBuffer, List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
createTableAsync(HTableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table but does not block and wait for it to come online.
createTableAsync(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates a new table but does not block and wait for it to come online.
createTableDescriptor(HTableDescriptor) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Create new HTableDescriptor in HDFS.
createTableDescriptor(HTableDescriptor, boolean) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Create new HTableDescriptor in HDFS.
createTableDescriptorForTableDirectory(Path, HTableDescriptor, boolean) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Create a new HTableDescriptor in HDFS in the specified table directory.
CreateTableHandler - Class in org.apache.hadoop.hbase.master.handler
Handler to create a table.
CreateTableHandler(Server, MasterFileSystem, HTableDescriptor, Configuration, HRegionInfo[], MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.CreateTableHandler
 
createTableLockManager(Configuration, ZooKeeperWatcher, ServerName) - Static method in class org.apache.hadoop.hbase.master.TableLockManager
Creates and returns a TableLockManager according to the configuration
CreateTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
 
CreateTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
CreateTableProcedure(MasterProcedureEnv, HTableDescriptor, HRegionInfo[]) - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
CreateTableProcedure(MasterProcedureEnv, HTableDescriptor, HRegionInfo[], ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
CreateTableProcedure.CreateHdfsRegions - Interface in org.apache.hadoop.hbase.master.procedure
 
createTempName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Generate a unique temporary Path.
createTempName(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Generate a unique temporary Path.
createThriftOneSource() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
Create a Source for a thrift one server
createThriftOneSource() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl
 
createThriftTwoSource() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
Create a Source for a thrift two server
createThriftTwoSource() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl
 
createTimer() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
createTmpWriter(Compactor.FileDetails, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
Creates a writer for a new file in a temporary directory.
createTopReference(byte[]) - Static method in class org.apache.hadoop.hbase.io.Reference
 
createTreeSet() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
createUnescapdArgument(byte[], int, int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Removes the single quote escaping a single quote - thus it returns an unescaped argument
createUserForTesting(Configuration, String, String[]) - Static method in class org.apache.hadoop.hbase.security.User
Generates a new User instance specifically for use in test code.
createUserForTesting(Configuration, String, String[]) - Static method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
 
createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
createVisibilityExpTags(String) - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
 
createVisibilityExpTags(String) - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
Convert visibility expression into tags to be serialized.
createVisibilityExpTags(String, boolean, boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
createVisibilityExpTags(String, boolean, boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
Creates tags corresponding to given visibility expression.
createVisibilityExpTags(String, boolean, boolean, Set<Integer>, VisibilityLabelOrdinalProvider) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
 
createVisibilityLabelFilter(Region, Authorizations) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
 
createWALWriter(FileSystem, Path) - Method in class org.apache.hadoop.hbase.wal.WALFactory
Create a writer for the WAL.
createWALWriter(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
If you already have a WALFactory, you should favor the instance method.
createWithParents(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node and all parent nodes required for it to exist.
createWithParents(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node and all parent nodes required for it to exist.
createWrapper(List<HTableInterface>, TableName, CoprocessorHost.Environment, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.HTableWrapper
 
createWriter(FileSystem, Path, FSDataOutputStream, KeyValue.KVComparator, HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
createWriter() - Method in interface org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter.WriterFactory
 
createWriter(InternalScanner, Compactor.FileDetails, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.Compactor.CellSinkFactory
 
createWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequest
 
createWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.SizeStripeFlushRequest
 
createWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
 
createWriter(Configuration, FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
public because of FSHLog.
createWriter(Path) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
Create a new WALProvider.Writer for writing log splits.
createWriterInstance(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
This method allows subclasses to inject different writers without having to extend other methods like rollWriter().
createWriterInTmp(long, Compression.Algorithm, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
createWriterInTmp(long, Compression.Algorithm, boolean, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
createWriterInTmp(long, Compression.Algorithm, boolean, boolean, boolean, boolean, TimeRangeTracker) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
createWriterInTmp(long, Compression.Algorithm, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
createWriterInTmp(long, Compression.Algorithm, boolean, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
createWriterInTmp(long, Compression.Algorithm, boolean, boolean, boolean, boolean, TimeRangeTracker) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
CREATOR_ALL_AND_WORLD_READABLE - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
CREDENTIALS_LOCATION - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
CRLF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
CRYPTO_ALTERNATE_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the name of the alternate cipher algorithm for the cluster, a string
CRYPTO_CIPHERPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the crypto algorithm provider, a class name
CRYPTO_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the algorithm used for creating jks key, a string
CRYPTO_KEYPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the crypto key provider, a class name
CRYPTO_KEYPROVIDER_PARAMETERS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the crypto key provider parameters
CRYPTO_MASTERKEY_ALTERNATE_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the name of the alternate master key for the cluster, a string
CRYPTO_MASTERKEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the name of the master key for the cluster, a string
CRYPTO_WAL_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the algorithm to use when encrypting the WAL, a string
CRYPTO_WAL_KEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the name of the master WAL encryption key for the cluster, a string
csm - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
ctx - Variable in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
 
cur_worker_name - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
CurCall - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
This is set to Call object before Handler invokes an RPC and ybdie after the call returns.
current() - Method in interface org.apache.hadoop.hbase.CellScanner
 
current() - Method in class org.apache.hadoop.hbase.client.Result
 
current() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
 
current() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
CellScanner
current - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
The current sub-scanner, i.e.
CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
currentBuffer - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
currentCellIndex - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
currentClientHasMinimumVersion(int, int) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
 
currentCompactedKVs - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
the completed count of key values in currently running compaction
CURRENTCOMPACTEDKVS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
currentComponent - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
 
CurrentHourProvider - Class in org.apache.hadoop.hbase.regionserver.compactions
 
currentKey - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
currentPositionIsAfter(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
internal methods
currentQueueLimit - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
currentRegion - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
currentRow - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
Row the query is on
currentRow() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
currentRowNode - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
currentTime() - Method in class org.apache.hadoop.hbase.util.DefaultEnvironmentEdge
Returns the currentTime.
currentTime() - Method in interface org.apache.hadoop.hbase.util.EnvironmentEdge
Returns the currentTime.
currentTime() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
Defers to the delegate and calls the EnvironmentEdge.currentTime() method.
currentTime() - Method in class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
Returns the currentTime.
currentTime() - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
 
currKeyLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
currMemstoreTS - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
currMemstoreTSLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
currValueLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
Cursor - Class in org.apache.hadoop.hbase.client
Scan cursor to tell client where server is scanning Scan.setNeedCursorResult(boolean) Result.isCursor() Result.getCursor()
cursor - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
cursor(boolean) - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
 
CursorPosition - Class in org.apache.hadoop.hbase.hbtop.terminal
A 2-d position in 'terminal space'.
CursorPosition(int, int) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
 
CUSTOM_CALLER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Configuration key for a custom RpcRetryingCaller
CUSTOM_CONTROLLER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
Custom RPC Controller factory allows frameworks to change the RPC controller.
CUSTOM_FILTERS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
CUSTOM_HEADER_PARAM - Static variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
 
CUSTOM_METHODS_TO_IGNORE_PARAM - Static variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
 
CUSTOM_RPC_CLIENT_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcClientFactory
 

D

D - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'D'
DaemonThreadFactory - Class in org.apache.hadoop.hbase
Thread factory that creates daemon threads
DaemonThreadFactory(String) - Constructor for class org.apache.hadoop.hbase.DaemonThreadFactory
 
DamagedWALException - Exception in org.apache.hadoop.hbase.regionserver.wal
Thrown when a failed append or sync on a WAL.
DamagedWALException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
 
DamagedWALException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
 
DamagedWALException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
 
DamagedWALException(Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
 
DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
DATA_BLOCK_ENCODING - Static variable in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Type of encoding used for data blocks in HFile.
DATA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
DATA_FILE_UMASK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
File permission umask to use when creating hbase data files
DATA_MANIFEST_NAME - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
DATA_SIZE_WITHOUT_WAL - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
DATA_SIZE_WITHOUT_WAL_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
dataAvailable - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.PipelineController
 
DATABLOCK_ENCODING_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
Deprecated.
 
DATABLOCK_ENCODING_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
DATABLOCK_READ_COUNT - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
 
DataBlockEncoder - Interface in org.apache.hadoop.hbase.io.encoding
Encoding of KeyValue.
dataBlockEncoder - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
What kind of data block encoding should be used while reading, writing, and handling cache.
DataBlockEncoder.EncodedSeeker - Interface in org.apache.hadoop.hbase.io.encoding
An interface which enable to seek while underlying data is encoded.
DataBlockEncoding - Enum in org.apache.hadoop.hbase.io.encoding
Provide access to all data block encoding algorithms.
dataBlockIndexReader - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Data block index reader keeping the root data index in memory
DataOutputOutputStream - Class in org.apache.hadoop.hbase.io
OutputStream implementation that wraps a DataOutput.
DataType<T> - Interface in org.apache.hadoop.hbase.types
DataType is the base class for all HBase data types.
date - Static variable in class org.apache.hadoop.hbase.Version
 
DATE_TIERED_COMPACTION_WINDOW_FACTORY_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
DATE_TIERED_INCOMING_WINDOW_MIN_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
DATE_TIERED_MAX_AGE_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
DATE_TIERED_SINGLE_OUTPUT_FOR_MINOR_COMPACTION_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
DateTieredCompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
HBASE-15181 This is a simple implementation of date-based tiered compaction similar to Cassandra's for the following benefits: Improve date-range-based scan by structuring store files in date-based tiered layout. Reduce compaction overhead. Improve TTL efficiency. Perfect fit for the use cases that: has mostly date-based data write and scan and a focus on the most recent data. Out-of-order writes are handled gracefully.
DateTieredCompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
 
DateTieredCompactionRequest - Class in org.apache.hadoop.hbase.regionserver.compactions
 
DateTieredCompactionRequest(Collection<StoreFile>, List<Long>) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionRequest
 
DateTieredCompactor - Class in org.apache.hadoop.hbase.regionserver.compactions
This compactor will generate StoreFile for different time ranges.
DateTieredCompactor(Configuration, Store) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactor
 
DateTieredMultiFileWriter - Class in org.apache.hadoop.hbase.regionserver
class for cell sink that separates the provided cells into multiple files for date tiered compaction.
DateTieredMultiFileWriter(List<Long>, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
 
DateTieredStoreEngine - Class in org.apache.hadoop.hbase.regionserver
HBASE-15400 This store engine allows us to store data in date tiered layout with exponential sizing so that the more recent data has more granularity.
DateTieredStoreEngine() - Constructor for class org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine
 
DAY_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
Seconds in a day, hour and minute
DEAD_REGION_SERVERS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
DEAD_REGION_SERVERS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
deadline - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
DEADNODES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
DeadServer - Class in org.apache.hadoop.hbase.master
Class to hold dead servers list and utility querying dead server list.
DeadServer() - Constructor for class org.apache.hadoop.hbase.master.DeadServer
 
deadServers - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
debugLsr(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
ls -r for debugging purposes
debugLsr(Configuration, Path, HBaseFsck.ErrorReporter) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
ls -r for debugging purposes
decActiveWorkerCount() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Decrement number of active thrift workers.
decActiveWorkerCount() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
decActiveWorkerCount() - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
decGauge(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Subtract some amount from a gauge.
decGauge(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
Decrease the value of a named gauge.
decGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
decGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
decGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.hadoop.hbase.security.SaslChallengeDecoder
 
decode(PositionedByteRange) - Method in interface org.apache.hadoop.hbase.types.DataType
Read an instance of T from the buffer src.
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedString
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.PBCell
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawByte
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawBytes
 
decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytes
Read a byte[] from the buffer src.
decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesFixedLength
Read a byte[] from the buffer src.
decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesTerminated
Read a byte[] from the buffer src.
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawDouble
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawFloat
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawInteger
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawLong
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawShort
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawString
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
 
decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.Struct
Read the field at index.
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
DECODE - Static variable in class org.apache.hadoop.hbase.util.Base64
Specify decoding.
decode(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Very low-level access to decoding ASCII characters in the form of a byte array.
decode(String) - Static method in class org.apache.hadoop.hbase.util.Base64
Decodes data from Base64 notation, automatically detecting gzip-compressed data and decompressing it.
decode(String, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Decodes data from Base64 notation, automatically detecting gzip-compressed data and decompressing it.
decode4to3(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Decodes four bytes from array source and writes the resulting bytes (up to three of them) to destination.
decodeA(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union2
Read an instance of the first type parameter from buffer src.
decodeAtPosition(int) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
decodeB(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union2
Read an instance of the second type parameter from buffer src.
decodeBlobCopy(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a Blob value, byte-for-byte copy.
decodeBlobVar(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a blob value that was encoded using BlobVar encoding.
decodeByte(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
Read a byte value from the buffer src.
decodeByte(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawByte
Read a byte value from the buffer buff.
decodeC(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union3
Read an instance of the third type parameter from buffer src.
decodeD(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union4
Read an instance of the fourth type parameter from buffer src.
decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
Read a double value from the buffer src.
decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Read a double value from the buffer src.
decodeDouble(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawDouble
Read a double value from the buffer buff.
decodeFirst() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
decodeFloat(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
Read a float value from the buffer dst.
decodeFloat(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawFloat
Read a float value from the buffer buff.
decodeFloat32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a 32-bit floating point value using the fixed-length encoding.
decodeFloat64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a 64-bit floating point value using the fixed-length encoding.
decodeFromFile(String) - Static method in class org.apache.hadoop.hbase.util.Base64
Convenience method for reading a base64-encoded file and decoding it.
decodeInt(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
Read an int value from the buffer src.
decodeInt(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawInteger
Read an int value from the buffer buff.
decodeInt16(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode an int16 value.
decodeInt32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode an int32 value.
decodeInt64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode an int64 value.
decodeInt8(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode an int8 value.
decodeKeyValues(DataInputStream, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
Deprecated.
 
decodeKeyValues(DataInputStream, int, int, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
Deprecated.
I don't think this method is called during normal HBase operation, so efficiency is not important.
decodeKeyValues(DataInputStream, HFileBlockDecodingContext) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Decode.
decodeKeyValues(DataInputStream, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
 
decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
Read a long value from the buffer src.
decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Read a long value from the buffer src.
decodeLong(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawLong
Read a long value from the buffer buff.
decodeMemstoreTS - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
decodeNext() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
decodeNumericAsBigDecimal(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a BigDecimal value from the variable-length encoding.
decodeNumericAsDouble(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a primitive double value from the Numeric encoding.
decodeNumericAsLong(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a primitive long value from the Numeric encoding.
decodeRemoteException(RemoteException) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
Deprecated.
Use RemoteException.unwrapRemoteException() instead. In fact we should look into deprecating this whole class - St.Ack 2010929
DecoderFactory - Class in org.apache.hadoop.hbase.codec.prefixtree.decode
Static wrapper class for the ArraySearcherPool.
DecoderFactory() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.DecoderFactory
 
decodeShort(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
Read a short value from the buffer src.
decodeShort(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawShort
Read a short value from the buffer buff.
decodeString(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a String value.
decodeTags() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
decodingCtx - Variable in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker
 
decompress(byte[], int, InputStream, int, int, Compression.Algorithm) - Static method in class org.apache.hadoop.hbase.io.compress.Compression
Decompresses data from the given stream using the configured compression algorithm.
decorateMasterConfiguration(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.Replication
This method modifies the master's configuration in order to inject replication-related features
decorateRegionServerConfiguration(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.Replication
This method modifies the region server's configuration in order to inject replication-related features
decorateTask(Runnable, RunnableScheduledFuture<V>) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl
 
decorateTask(Callable<V>, RunnableScheduledFuture<V>) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl
 
decrement() - Method in interface org.apache.hadoop.hbase.metrics.Counter
Decrement this by 1.
decrement(long) - Method in interface org.apache.hadoop.hbase.metrics.Counter
Decrement this by n.
decrement() - Method in class org.apache.hadoop.hbase.metrics.impl.CounterImpl
 
decrement(long) - Method in class org.apache.hadoop.hbase.metrics.impl.CounterImpl
 
decrement() - Method in class org.apache.hadoop.hbase.util.Counter
 
decrement() - Method in class org.apache.hadoop.hbase.util.LongAdder
Equivalent to add(-1).
decrementCompactionsQueuedCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
decRpcCount() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
decrSizeOfHFileRefsQueue(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
decrSizeOfHFileRefsQueue(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
decrSizeOfHFileRefsQueue(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
decrSizeOfHFileRefsQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
decrSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
decrSizeOfLogQueue(int) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
decrSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
decrSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
decrypt(byte[], int, InputStream, int, Decryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypt a block of ciphertext read in from a stream with the given cipher and context
decrypt(byte[], int, InputStream, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypt a block of ciphertext from a stream given a context and IV
decrypt(OutputStream, InputStream, int, Decryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypt a stream of ciphertext given a decryptor
decrypt(OutputStream, InputStream, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypt a stream of ciphertext given a context and IV
Decryptor - Interface in org.apache.hadoop.hbase.io.crypto
Decryptors apply a cipher to an InputStream to recover plaintext.
decryptWithSubjectKey(OutputStream, InputStream, int, String, Configuration, Cipher, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypts a block of ciphertext with the symmetric key resolved for the given subject
decScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
Called when closing a scanner on the data of this MemStoreLAB
decScannerCount() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
Called when closing a scanner on the data of this MemStoreLAB
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
deepClone() - Method in interface org.apache.hadoop.hbase.security.visibility.expression.ExpressionNode
 
deepClone() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
 
deepClone() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
 
deepCopy() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
deepCopy() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
deepCopy() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
deepCopy() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
deepCopy() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
deepCopy() - Method in interface org.apache.hadoop.hbase.util.ByteRange
Create a new ByteRange with new backing byte[] containing a copy of the content from this range's window.
deepCopy() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
deepCopySubRangeTo(int, int, byte[], int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
deepCopySubRangeTo(int, int, byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Wrapper for System.arraycopy.
deepCopyTo(byte[], int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
deepCopyTo(byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Wrapper for System.arraycopy.
deepCopyToNewArray() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
deepCopyToNewArray() - Method in interface org.apache.hadoop.hbase.util.ByteRange
Instantiate a new byte[] with exact length, which is at least 24 bytes + length.
DEFAULT_ABORT_ON_ERROR - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
DEFAULT_AGGREGATION_WINDOW - Static variable in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
 
DEFAULT_ATTRIBUTE_EARLY_OUT - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Default setting for hbase.security.access.early_out
DEFAULT_ATTRIBUTES_COLUMN_INDEX - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to use a block cache or not.
DEFAULT_BLOCKING_STOREFILE_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default size of blocks in files stored to the filesytem (hfiles).
DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Default block size for an HFile.
DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether or not to use bloomfilters.
DEFAULT_BUCKET_CACHE_COMBINED - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Defaults for Bucket cache
DEFAULT_BUCKET_CACHE_WRITER_QUEUE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_BUCKET_CACHE_WRITER_THREADS - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
The number of bytes per checksum.
DEFAULT_BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
DEFAULT_BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache bloom filter blocks on write if block caching is enabled.
DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_CACHE_DATA_COMPRESSED - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache data blocks in L1 tier.
DEFAULT_CACHE_DATA_ON_READ - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache data blocks on write if block caching is enabled.
DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_CACHE_FLUSH_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
Default interval for the memstore flush
DEFAULT_CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to cache index blocks on write if block caching is enabled.
DEFAULT_CACHE_INDEXES_ON_WRITE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_CALL_QUEUE_SIZE_HARD_LIMIT - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
DEFAULT_CELL_TTL_COLUMN_INDEX - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
DEFAULT_CELL_VISIBILITY_COLUMN_INDEX - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
DEFAULT_CLUSTER_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for cluster distributed mode
DEFAULT_CLUSTER_ID - Static variable in class org.apache.hadoop.hbase.HConstants
Default cluster ID, cannot be used to identify a cluster so a key with this value means it wasn't meant for replication.
DEFAULT_CODEC_CLASS - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_COMPACTCHECKER_INTERVAL_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
DEFAULT_COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes whether the table is compaction enabled by default
DEFAULT_COMPACTION_POLICY_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
DEFAULT_COMPACTOR_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
DEFAULT_COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default compress tags along with any type of DataBlockEncoding.
DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default compression type.
DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Default compression name: none.
DEFAULT_COMPRESSION_ALGORITHM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Default compression: none.
DEFAULT_CONCURRENCY_LEVEL - Static variable in class org.apache.hadoop.hbase.util.WeakObjectPool
The default concurrency level, used when not otherwise specified in a constructor.
DEFAULT_COPROCESSORS_ENABLED - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default data block encoding algorithm.
DEFAULT_DELEGATE_PROVIDER - Static variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
DEFAULT_DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
DEFAULT_DISALLOW_WRITES_IN_RECOVERING_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_DISTRIBUTED_LOG_REPLAY_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_ENABLE_CLIENT_BACKPRESSURE - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default value of the flag that enables data block encoding on disk, as opposed to encoding in cache only.
DEFAULT_END_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.rest.RowSpec
 
DEFAULT_ERROR_TOLERATION_DURATION - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
DEFAULT_EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to evict cached blocks from the blockcache on close.
DEFAULT_EVICT_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_EXEC_PERMISSION_CHECKS - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Default setting for hbase.security.exec.permission.checks; false
DEFAULT_EXECUTOR_ABORT_ON_CORRUPTION - Static variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureConstants
 
DEFAULT_EXPIRATION_TIME - Static variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
DEFAULT_FLUSH_PER_CHANGES - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEFAULT_GROUP - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
DEFAULT_HBASE_BALANCER_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for the balancer period
DEFAULT_HBASE_CELLS_SCANNED_PER_HEARTBEAT_CHECK - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
DEFAULT_HBASE_CLIENT_MAX_PERREGION_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_MAX_PERSERVER_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_MAX_TOTAL_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Default HBase client operation timeout, which is tantamount to a blocking call
DEFAULT_HBASE_CLIENT_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum number of bytes returned when calling a scanner's next method.
DEFAULT_HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_CONFIG_READ_ZOOKEEPER_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HBASE_HTTP_STATIC_USER - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
 
DEFAULT_HBASE_JETTY_LOGS_SERVE_ALIASES - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
 
DEFAULT_HBASE_MASTER_BALANCER_MAX_RIT_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for the max percent of regions in transition
DEFAULT_HBASE_META_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_META_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_RPC_SHORTOPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_RPC_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
DEFAULT_HBASE_SERVER_SCANNER_MAX_RESULT_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum number of bytes returned when calling a scanner's next method.
DEFAULT_HEALTH_FAILURE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HEALTH_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HEAP_OCCUPANCY_HIGH_WATERMARK - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HEAP_OCCUPANCY_LOW_WATERMARK - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HFILE_DELETE_THROTTLE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
DEFAULT_HOST - Static variable in class org.apache.hadoop.hbase.HConstants
default host address
DEFAULT_HREGION_EDITS_REPLAY_SKIP_ERRORS - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HREGION_MEMSTORE_BLOCK_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for hbase.hregion.memstore.block.multiplier
DEFAULT_HREGION_MVCC_PRE_ASSIGN - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEFAULT_HSTORE_OPEN_AND_CLOSE_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
The default number for the max number of threads used for opening and closing stores or store files in parallel
DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for whether to try and serve this column family from memory or not.
DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_INITIAL_CAPACITY - Static variable in class org.apache.hadoop.hbase.util.WeakObjectPool
The default initial capacity, used when not otherwise specified in a constructor.
DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default setting for preventing deleted from being collected immediately.
DEFAULT_KEYVALUE_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Strings
 
DEFAULT_LARGE_HFILE_DELETE_THREAD_NUMBER - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
DEFAULT_LARGE_HFILE_QUEUE_INIT_SIZE - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
DEFAULT_LISTEN_PORT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
DEFAULT_LISTEN_PORT - Static variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
 
DEFAULT_LISTEN_PORT - Static variable in class org.apache.hadoop.hbase.thrift2.ThriftServer
 
DEFAULT_LOCAL_DIR - Static variable in class org.apache.hadoop.hbase.util.ClassLoaderBase
 
DEFAULT_LOSSY_COUNTING_ERROR_RATE - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_MASTER_HANLDER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_MASTER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
default port for master web api
DEFAULT_MASTER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
default port that the master listens on
DEFAULT_MASTER_TYPE_BACKUP - Static variable in class org.apache.hadoop.hbase.HConstants
by default every master is a possible primary master unless the conf explicitly overrides it
DEFAULT_MATH_CONTEXT - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
The context used to normalize BigDecimal values.
DEFAULT_MAX - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
 
DEFAULT_MAX_AGE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
DEFAULT_MAX_BACKOFF - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
DEFAULT_MAX_BLOCKED_REQUESTS - Static variable in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
 
DEFAULT_MAX_CELL_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEFAULT_MAX_FILE_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Default maximum file size
DEFAULT_MAX_QUEUED_REQUESTS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
 
DEFAULT_MAX_REQUEST_SIZE - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
Default value for above params
DEFAULT_MAX_RESUBMIT - Static variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
DEFAULT_MAX_SPLITTERS - Static variable in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
 
DEFAULT_MAX_TASKS - Static variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
DEFAULT_MAX_WAIT_TIME - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
By default, wait 300 seconds for a snapshot to complete
DEFAULT_MAX_WORKER_THREADS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
 
DEFAULT_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes the maximum default size of the memstore after which the contents are flushed to the store files
DEFAULT_MEMSTORE_SIZE - Static variable in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
 
DEFAULT_MEMSTORE_SIZE_LOWER_LIMIT - Static variable in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
 
DEFAULT_META_REPLICA_NUM - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_MIN_AGE_MS - Static variable in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
 
DEFAULT_MIN_MASTER_PROCEDURE_THREADS - Static variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureConstants
 
DEFAULT_MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default is not to keep a minimum of versions.
DEFAULT_MIN_WORKER_THREADS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
This default core pool size should be enough for many test scenarios.
DEFAULT_MONITOR_INTERVAL - Static variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
DEFAULT_NAMESPACE - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
DEFAULT_NAMESPACE_NAME - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
Default namespace name.
DEFAULT_NAMESPACE_NAME_STR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
DEFAULT_NBINS - Static variable in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
Default number of bins.
DEFAULT_NBINS - Static variable in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
Default number of bins.
DEFAULT_NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes whether the table is normalized by default.
DEFAULT_OLD_WALS_CLEANER_THREAD_SIZE - Static variable in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
 
DEFAULT_PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
DEFAULT_PREFETCH_ON_OPEN - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_QUANTILES - Static variable in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
 
DEFAULT_QUANTILES - Static variable in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
DEFAULT_READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes whether the table is READONLY by default and is false
DEFAULT_REASSIGN_WAIT_INTERVAL - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
 
DEFAULT_REGION_GROUPING_STRATEGY - Static variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
DEFAULT_REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
DEFAULT_REGION_REPLICA_WAIT_FOR_PRIMARY_FLUSH - Static variable in class org.apache.hadoop.hbase.client.RegionReplicaUtil
 
DEFAULT_REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
DEFAULT_REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGION_SERVER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGION_SERVER_REGION_SPLIT_LIMIT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
DEFAULT_REGION_SERVER_REPLICATION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGIONSERVER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
default port for region server web api
DEFAULT_REGIONSERVER_METRICS_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGIONSERVER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Default port region server listens on.
DEFAULT_REPLICA_ID - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
DEFAULT_REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default scope.
DEFAULT_RETRIES_ON_META - Static variable in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
DEFAULT_RPC_WARN_TIME - Static variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
DEFAULT_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Strings
 
DEFAULT_SHORT_WAIT_ON_META - Static variable in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
DEFAULT_SLEEP_BEFORE_RERUN - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck
 
DEFAULT_SLOW_RESPONSE_NANO_SEC - Static variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
DEFAULT_SMALL_HFILE_DELETE_THREAD_NUMBER - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
DEFAULT_SMALL_HFILE_QUEUE_INIT_SIZE - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
DEFAULT_SNAPSHOT_TTL - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_SNAPSHOT_TTL_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_SOCKET_TIMEOUT_CONNECT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_SOCKET_TIMEOUT_READ - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_SOCKET_TIMEOUT_WRITE - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_START_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.rest.RowSpec
 
DEFAULT_STATUS_MULTICAST_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_STATUS_MULTICAST_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_STATUS_MULTICAST_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_STATUS_PUBLISH_PERIOD - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
 
DEFAULT_STATUS_PUBLISHER_CLASS - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
 
DEFAULT_STORE_FLUSHER_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
DEFAULT_TABLE_LOCK_EXPIRE_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
 
DEFAULT_TABLE_READ_LOCK_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
 
DEFAULT_TABLE_WRITE_LOCK_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
 
DEFAULT_TEMPORARY_HDFS_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_THREAD_WAKE_FREQUENCY - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for thread wake frequency
DEFAULT_TIME_LAG - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck
 
DEFAULT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
DEFAULT_TIMESTAMP_COLUMN_INDEX - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
DEFAULT_TRACE_LOG_MAX_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default time to live of cell contents.
DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
 
DEFAULT_TYPE - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
DEFAULT_UNASSIGNED_TIMEOUT - Static variable in class org.apache.hadoop.hbase.master.SplitLogManager
 
DEFAULT_USE_META_REPLICAS - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_USER_COPROCESSORS_ENABLED - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
DEFAULT_VERSION_FILE_WRITE_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for how often we should try to write a version file, before failing
DEFAULT_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default number of versions of a record to keep.
DEFAULT_WAIT_ON_RIT - Static variable in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
DEFAULT_WAL_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_WRITE_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.tool.CanaryTool
 
DEFAULT_ZK_RETRIES - Static variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
DEFAULT_ZK_SESSION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for ZooKeeper session timeout
DEFAULT_ZOOKEEPER_ZNODE_PARENT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_ZOOKEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Default client port that the zookeeper listens on
DEFAULT_ZOOKEPER_MAX_CLIENT_CNXNS - Static variable in class org.apache.hadoop.hbase.HConstants
Default limit on concurrent client-side zookeeper connections
DEFAULT_ZOOKEPER_RECOVERABLE_WAITIME - Static variable in class org.apache.hadoop.hbase.HConstants
Default wait time for the recoverable zookeeper
DefaultCipherProvider - Class in org.apache.hadoop.hbase.io.crypto
The default cipher provider.
DefaultCompactor - Class in org.apache.hadoop.hbase.regionserver.compactions
Compact passed set of files.
DefaultCompactor(Configuration, Store) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
 
defaultContexts - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
DefaultEnvironmentEdge - Class in org.apache.hadoop.hbase.util
Default implementation of an environment edge.
DefaultEnvironmentEdge() - Constructor for class org.apache.hadoop.hbase.util.DefaultEnvironmentEdge
 
DefaultMemStore - Class in org.apache.hadoop.hbase.regionserver
The MemStore holds in-memory modifications to the Store.
DefaultMemStore() - Constructor for class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Default constructor.
DefaultMemStore(Configuration, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Constructor.
DefaultMemStore.MemStoreScanner - Class in org.apache.hadoop.hbase.regionserver
 
DefaultMetricsSystemHelper - Class in org.apache.hadoop.metrics2.lib
 
DefaultMetricsSystemHelper() - Constructor for class org.apache.hadoop.metrics2.lib.DefaultMetricsSystemHelper
 
DefaultOperationQuota - Class in org.apache.hadoop.hbase.quotas
 
DefaultOperationQuota(QuotaLimiter...) - Constructor for class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
DefaultOperationQuota(List<QuotaLimiter>) - Constructor for class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
NOTE: The order matters.
defaultPool(String, int) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
Default thread pool for the procedure
defaultPool(String, int, long) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
Default thread pool for the procedure
defaultPool(String, int) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureMember
Default thread pool for the procedure
defaultPool(String, int, long) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureMember
Default thread pool for the procedure
defaultScannerFactory - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
DefaultSourceFSConfigurationProvider - Class in org.apache.hadoop.hbase.replication.regionserver
This will load all the xml configuration files for the source cluster replication ID from user configured replication configuration directory.
DefaultSourceFSConfigurationProvider() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.DefaultSourceFSConfigurationProvider
 
DefaultStoreEngine - Class in org.apache.hadoop.hbase.regionserver
Default StoreEngine creates the default compactor, policy, and store file manager, or their derivatives.
DefaultStoreEngine() - Constructor for class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
DefaultStoreFlusher - Class in org.apache.hadoop.hbase.regionserver
Default implementation of StoreFlusher.
DefaultStoreFlusher(Configuration, Store) - Constructor for class org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher
 
DefaultVisibilityExpressionResolver - Class in org.apache.hadoop.hbase.mapreduce
This implementation creates tags by expanding expression using label ordinal.
DefaultVisibilityExpressionResolver() - Constructor for class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
 
DefaultVisibilityLabelServiceImpl - Class in org.apache.hadoop.hbase.security.visibility
 
DefaultVisibilityLabelServiceImpl() - Constructor for class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
DefaultWALProvider - Class in org.apache.hadoop.hbase.wal
A WAL Provider that returns a single thread safe WAL that writes to Hadoop FS.
DefaultWALProvider() - Constructor for class org.apache.hadoop.hbase.wal.DefaultWALProvider
 
DefaultWALProvider.Reader - Interface in org.apache.hadoop.hbase.wal
 
DefaultWALProvider.Writer - Interface in org.apache.hadoop.hbase.wal
 
DEFERRED_LOG_FLUSH - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
DefinedSetFilterScanLabelGenerator - Class in org.apache.hadoop.hbase.security.visibility
This is an implementation for ScanLabelGenerator.
DefinedSetFilterScanLabelGenerator() - Constructor for class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
 
defineFilter(Context, String, String, Map<String, String>, String[]) - Static method in class org.apache.hadoop.hbase.http.HttpServer
Define a filter for a context and set up default url mappings.
defMasterRMIRegistryPort - Static variable in class org.apache.hadoop.hbase.JMXListener
 
defRegionserverRMIRegistryPort - Static variable in class org.apache.hadoop.hbase.JMXListener
 
DelayingRunner<T> - Class in org.apache.hadoop.hbase.client
A wrapper for a runnable for a group of actions for a single regionserver.
DelayingRunner(long, Map.Entry<byte[], List<Action<T>>>) - Constructor for class org.apache.hadoop.hbase.client.DelayingRunner
 
delegate - Variable in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
DELEGATE_PROVIDER - Static variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
delegate provider for WAL creation/roll/close
DelegatingHBaseRpcController - Class in org.apache.hadoop.hbase.ipc
Simple delegating controller for use with the RpcControllerFactory to help override standard behavior of a HBaseRpcController.
DelegatingHBaseRpcController(HBaseRpcController) - Constructor for class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
DelegatingRetryingCallable<T,D extends RetryingCallable<T>> - Class in org.apache.hadoop.hbase.client
Helper callable for internal use when you just want to override a single method of a RetryingCallable.
DelegatingRetryingCallable(D) - Constructor for class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
Delete - Class in org.apache.hadoop.hbase.client
Used to perform Delete operations on a single row.
Delete(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row.
Delete(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row and timestamp.
Delete(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row and timestamp.
Delete(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row and timestamp.
Delete(Delete) - Constructor for class org.apache.hadoop.hbase.client.Delete
 
delete(Delete) - Method in class org.apache.hadoop.hbase.client.HTable
Deletes the specified cells/row.
delete(List<Delete>) - Method in class org.apache.hadoop.hbase.client.HTable
Deletes the specified cells/rows in bulk.
delete(Delete) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
delete(List<Delete>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
delete(Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Deletes the specified cells/row.
delete(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.Table
Deletes the specified cells/rows in bulk.
delete(RpcController, BulkDeleteProtos.BulkDeleteRequest, RpcCallback<BulkDeleteProtos.BulkDeleteResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
 
delete(RpcController, BulkDeleteProtos.BulkDeleteRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService.BlockingInterface
 
delete(RpcController, BulkDeleteProtos.BulkDeleteRequest, RpcCallback<BulkDeleteProtos.BulkDeleteResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
rpc delete(.hbase.pb.BulkDeleteRequest) returns (.hbase.pb.BulkDeleteResponse);
delete(RpcController, BulkDeleteProtos.BulkDeleteRequest, RpcCallback<BulkDeleteProtos.BulkDeleteResponse>) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService.Interface
rpc delete(.hbase.pb.BulkDeleteRequest) returns (.hbase.pb.BulkDeleteResponse);
delete(RpcController, BulkDeleteProtos.BulkDeleteRequest, RpcCallback<BulkDeleteProtos.BulkDeleteResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService.Stub
 
delete() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
delete(long) - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
 
delete(Procedure, long[]) - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
 
delete(long) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
The specified procId was removed from the executor, due to completion, abort or failure.
delete(Procedure, long[]) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
The parent procedure completed.
delete(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
delete(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
delete(long[]) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
delete(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
delete(Procedure, long[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
delete(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Write a delete
delete(Delete) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
delete(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Adds a value to the memstore
delete(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Write a delete
delete(Delete) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Deletes the specified cells/row.
delete(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a DELETE request
delete(String, Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a DELETE request
delete(Cluster, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a DELETE request
delete(Cluster, String, Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a DELETE request
delete(Delete) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
delete(List<Delete>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
delete(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
 
delete(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
 
delete(UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
 
delete(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Calls fs.delete() and returns the value returned by the fs.delete()
delete(String, int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
delete is an idempotent operation.
DELETE_BATCH_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
DELETE_BATCH_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
 
DELETE_FAMILY_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Delete Family Count in FileInfo
DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
DELETE_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
 
deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Delete all cells that match the passed row and column.
deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
deleteAllConnections(boolean) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated. 
deleteAllConnections() - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
kept for backward compatibility, but the behavior is broken. HBASE-8983
deleteAllNodes(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes all unassigned nodes regardless of their state.
deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Completely delete the row's cells.
deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Completely delete the row's cells marked with a timestamp equal-to or older than the passed timestamp.
deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Delete all cells that match the passed row and column and whose timestamp is equal-to or older than the passed timestamp.
deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
deleteAssignmentState(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
deleteBuffer - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
deleteCachedRegionLocation(HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Deletes cached locations for the specific region.
deleteCachedRegionLocation(HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
deleteChangedReaderObserver(ChangedReadersObserver) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
deleteChangedReaderObserver(ChangedReadersObserver) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
deleteChildrenRecursively(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete all the children of the specified node but not the node itself.
deleteChildrenRecursivelyMultiOrSequential(ZooKeeperWatcher, boolean, String...) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete all the children of the specified node but not the node itself.
deleteClosedNode(ZooKeeperWatcher, String, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the CLOSED state for the specified region.
deleteClosingNode(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the CLOSING state for the specified region.
deleteClosingOrClosedNode(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
deleteColumn(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete a column from a table.
deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
Since hbase-1.0.0. Use Delete.addColumn(byte[], byte[])
deleteColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
deleteColumn(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete a column from a table.
deleteColumn(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete a column from a table.
deleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete a column from a table.
deleteColumn(TableName, byte[], long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
deleteColumn(RpcController, MasterProtos.DeleteColumnRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
deleteColumn(TableName, byte[], long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Delete a column from an existing table
deleteColumnFamilyFromFileSystem(MasterProcedureEnv, TableName, List<HRegionInfo>, byte[]) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterDDLOperationHelper
Remove the column family from the file system
DeleteColumnFamilyProcedure - Class in org.apache.hadoop.hbase.master.procedure
The procedure to delete a column family from an existing table.
DeleteColumnFamilyProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
DeleteColumnFamilyProcedure(MasterProcedureEnv, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
deleteColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
Since hbase-1.0.0. Use Delete.addColumns(byte[], byte[])
deleteColumns(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
deleteConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated. 
deleteDirectory(MasterProcedureEnv, String) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
Delete the namespace directories from the file system
deleteDirectory(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Delete if exists.
deleteFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
Since 1.0.0. Use Delete.addFamily(byte[])
deleteFamily(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
deleteFamily(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Remove the region family from disk, archiving the store files.
deleteFamilyBloomFilter - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
deleteFamilyFromFS(HRegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
deleteFamilyVersion(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
deleteFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
Delete the given files
deleteFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
deleteFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
 
deleteFromFs(MasterProcedureEnv, TableName, List<HRegionInfo>, boolean) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
deleteFromHBase(Delete) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
 
deleteFromMeta(MasterProcedureEnv, TableName, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
deleteFromMetaTable(Connection, List<Delete>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Delete the passed deletes from the hbase:meta table.
deleteFromNSTable(MasterProcedureEnv, String) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
delete the row from namespace table
deleteFromThrift(TDelete) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
Creates a Delete (HBase) from a TDelete (Thrift).
deleteIfEquals(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
delete the master znode if its content is same as the parameter
deleteLength - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
deleteMergeQualifiers(Connection, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes merge qualifiers for the specified merged region.
deleteMetaLocation(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Deletes the location of hbase:meta in ZooKeeper.
deleteMetaLocation(ZooKeeperWatcher, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
deleteMultiple(ByteBuffer, List<TDelete>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
deleteMultiple(ByteBuffer, List<TDelete>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
deleteMultiple(ByteBuffer, List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
deleteMultiple(ByteBuffer, List<TDelete>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Bulk commit a List of TDeletes to the table.
deleteMultiple(ByteBuffer, List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
deleteMyEphemeralNodeOnDisk() - Static method in class org.apache.hadoop.hbase.ZNodeClearer
delete the znode file
deleteNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete an existing namespace.
deleteNamespace(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete an existing namespace.
deleteNamespace(String, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
deleteNamespace(RpcController, MasterProtos.DeleteNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
deleteNamespace(String, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Delete an existing namespace.
deleteNamespace(String) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
 
deleteNamespaceACLNode(String) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
Delete the acl notify node of namespace
DeleteNamespaceProcedure - Class in org.apache.hadoop.hbase.master.procedure
The procedure to remove a namespace.
DeleteNamespaceProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
DeleteNamespaceProcedure(MasterProcedureEnv, String) - Constructor for class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
deleteNamespaceQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
deleteNoBody(byte[], UriInfo, HttpHeaders) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
Build a response for DELETE delete namespace.
deleteNode(ZooKeeperWatcher, String, EventType, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the specified state for the specified region.
deleteNode(ZooKeeperWatcher, String, EventType, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the specified state for the specified region.
deleteNode(ZooKeeperWatcher, String, EventType, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the specified state for the specified region.
deleteNode(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node.
deleteNode(ZooKeeperWatcher, String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node with the specified version.
deleteNodeFailSilent(ZooKeeperWatcher, HRegionInfo) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Delete the assignment node regardless of its current state.
deleteNodeFailSilent(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Deletes the specified node.
deleteNodeFailSilent(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
 
deleteNodeRecursively(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node and all of it's children.
deleteNodeRecursivelyMultiOrSequential(ZooKeeperWatcher, boolean, String...) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node and its children.
deleteOfflineNode(ZooKeeperWatcher, String, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the OFFLINE state for the specified region.
deleteOffset - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
deleteOpenedNode(ZooKeeperWatcher, String, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Deletes an existing unassigned node that is in the OPENED state for the specified region.
deleteReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
Delete this file
deleteRecoveringRegionZNodes(ZooKeeperWatcher, List<String>) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
deleteRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
Remove a region from all state maps.
deleteRegion(Connection, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes the specified region from META.
deleteRegionDir(Configuration, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Delete the region directory if exists.
deleteRegionFromFileSystem(Configuration, FileSystem, Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Remove the region from the table directory, archiving the region's hfiles.
deleteRegions(Connection, List<HRegionInfo>, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes the specified regions from META.
deleteRegions(Connection, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes the specified regions from META.
deleteRoot() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
Remove the -ROOT- dir.
deletes - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
Keeps track of deletes
deletesFromThrift(List<TDelete>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
Converts multiple TDeletes (Thrift) into a list of Deletes (HBase).
deleteShutdownHook(Runnable) - Static method in class org.apache.hadoop.hbase.util.ShutdownHookManager
 
deleteSingle(ByteBuffer, TDelete, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
deleteSingle(ByteBuffer, TDelete, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
deleteSingle(ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
deleteSingle(ByteBuffer, TDelete) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Deletes as specified by the TDelete.
deleteSingle(TDelete) - Static method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
deleteSingle(ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
deleteSnapshot(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete an existing snapshot.
deleteSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete an existing snapshot.
deleteSnapshot(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete an existing snapshot.
deleteSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete an existing snapshot.
deleteSnapshot(RpcController, MasterProtos.DeleteSnapshotRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Execute Delete Snapshot operation.
deleteSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Delete the specified snapshot
deleteSnapshots(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete existing snapshots whose names match the pattern passed.
deleteSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete existing snapshots whose names match the pattern passed.
deleteSnapshots(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete existing snapshots whose names match the pattern passed.
deleteSnapshots(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete existing snapshots whose names match the pattern passed.
deleteSource(String, boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Delete a complete queue of wals associated with a peer cluster
deleteStaleConnection(HConnection) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated. 
deleteTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Deletes a table.
deleteTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deletes a table.
deleteTable(TableName, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
deleteTable(RpcController, MasterProtos.DeleteTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
deleteTable(TableName, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Delete a table
deleteTable(String) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
Deletes a table.
deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
Deletes a table.
deleteTable(ByteBuffer, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
deleteTable(ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
deleteTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
deleteTable(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Deletes a table
deleteTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
deleteTableACLNode(TableName) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
Delete the acl notify node of table
deleteTableDescriptorCache(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
deleteTableDescriptorIfExists(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Deletes all the table descriptor files from the file system.
DeleteTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
 
DeleteTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
DeleteTableProcedure(MasterProcedureEnv, TableName) - Constructor for class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
DeleteTableProcedure(MasterProcedureEnv, TableName, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
deleteTableQuota(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
deleteTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deletes tables matching the passed in pattern and wait on completion.
deleteTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete tables matching the passed in pattern and wait on completion.
deleteTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deletes tables matching the passed in pattern and wait on completion.
deleteTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete tables matching the passed in pattern and wait on completion.
deleteTableSnapshots(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete all existing snapshots matching the given table name regular expression and snapshot name regular expression.
deleteTableSnapshots(Pattern, Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete all existing snapshots matching the given table name regular expression and snapshot name regular expression.
deleteTableSnapshots(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete all existing snapshots matching the given table name regular expression and snapshot name regular expression.
deleteTableSnapshots(Pattern, Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete all existing snapshots matching the given table name regular expression and snapshot name regular expression.
deleteTableStates(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
deleteTask(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
 
deleteTask(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
deleteTimestamp - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
deleteTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
DeleteTracker - Interface in org.apache.hadoop.hbase.regionserver
This interface is used for the tracking and enforcement of Deletes during the course of a Get or Scan operation.
DeleteTracker.DeleteCompare - Enum in org.apache.hadoop.hbase.regionserver
Return codes for comparison of two Deletes.
DeleteTracker.DeleteResult - Enum in org.apache.hadoop.hbase.regionserver
Returns codes for delete result.
deleteType - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
deleteType - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
DELETETYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
deleteUserQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
deleteUserQuota(Connection, String, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
deleteUserQuota(Connection, String, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
DeletionListener - Class in org.apache.hadoop.hbase.zookeeper
A ZooKeeper watcher meant to detect deletions of ZNodes.
DeletionListener(ZooKeeperWatcher, String, CountDownLatch) - Constructor for class org.apache.hadoop.hbase.zookeeper.DeletionListener
Create a new instance of the deletion watcher.
DelimitedKeyPrefixRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
A custom RegionSplitPolicy implementing a SplitPolicy that groups rows by a prefix of the row-key with a delimiter.
DelimitedKeyPrefixRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
 
DELIMITER - Static variable in class org.apache.hadoop.hbase.HConstants
delimiter used between portions of a region name
DELIMITER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
 
DemoClient - Class in org.apache.hadoop.hbase.thrift
See the instructions under hbase-examples/README.txt
DemoClient - Class in org.apache.hadoop.hbase.thrift2
 
DemoClient() - Constructor for class org.apache.hadoop.hbase.thrift2.DemoClient
 
deny(String, String, User, Permission.Action, String) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
 
deny(String, String, User, Permission.Action, TableName, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
 
deny(String, String, User, Permission.Action, TableName, Map<byte[], ? extends Collection<?>>) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
 
DependentColumnFilter - Class in org.apache.hadoop.hbase.filter
A filter for adding inter-column timestamp matching Only cells with a correspondingly timestamped entry in the target column will be retained Not compatible with Scan.setBatch as operations need full rows for correct filtering
DependentColumnFilter(byte[], byte[], boolean, CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
Build a dependent column filter with value checking dependent column varies will be compared using the supplied compareOp and comparator, for usage of which refer to CompareFilter
DependentColumnFilter(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
Constructor for DependentColumn filter.
DependentColumnFilter(byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
Constructor for DependentColumn filter.
dequeuedCall(int) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
dequeuedCall(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
deregister(MetricsRegionSource) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
Remove a region's source.
deregister(MetricsRegionSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
 
deregister(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
Remove a table's source.
deregister(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
 
deregisterChildren(ConfigurationManager) - Method in interface org.apache.hadoop.hbase.conf.PropagatingConfigurationObserver
Needs to be called to deregister the children from the manager.
deregisterChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
Needs to be called to deregister the children from the manager.
deregisterChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Needs to be called to deregister the children from the manager.
deregisterChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Needs to be called to deregister the children from the manager.
deregisterObserver(ConfigurationObserver) - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
Deregister an observer class
desc - Variable in class org.apache.hadoop.metrics2.lib.MutableHistogram
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
 
descendingIterator() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
descendingKeySet() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
descendingMap() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
descendingSet() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
descendToLastRowFromCurrentPosition() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayReversibleScanner
 
DESCRIPTOR_VERSION - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV1
 
DESCRIPTOR_VERSION - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2
 
DeserializationException - Exception in org.apache.hadoop.hbase.exceptions
Failed deserialization.
DeserializationException() - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
 
DeserializationException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
 
DeserializationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
 
DeserializationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
 
deserialize(byte[]) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
Takes a series of bytes and tries to generate an ForeignException instance for it.
deserialize(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.hfile.CacheableDeserializer
Returns the deserialized object.
deserialize(ByteBuffer, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.CacheableDeserializer
 
deserialize(KeyValue) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueDeserializer
 
deserialize(byte[]) - Static method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
Takes a series of bytes and tries to generate an RemoteProcedureException instance for it.
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called on store load to allow the user to decode the previously serialized state.
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureInMemoryChore
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.procedure2.SequentialProcedure
 
deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
 
destroy() - Method in class org.apache.hadoop.hbase.http.ClickjackingPreventionFilter
 
destroy() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
 
destroy() - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
 
destroy() - Method in class org.apache.hadoop.hbase.http.NoCacheFilter
 
destroy() - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
 
destroy() - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
 
destroyDirectByteBuffer(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
DirectByteBuffers are garbage collected by using a phantom reference and a reference queue.
detail(String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
Dictionary - Interface in org.apache.hadoop.hbase.io.util
Dictionary interface Dictionary indexes should be either bytes or shorts, only positive.
difference - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
fields
DiffKeyDeltaEncoder - Class in org.apache.hadoop.hbase.io.encoding
Compress using: - store size of common prefix - save column family once, it is same within HFile - use integer compression for key, value and prefix (7-bit encoding) - use bits to avoid duplication key length, value length and type if it same as previous - store in 3 bits length of timestamp field - allow diff in timestamp instead of actual value Format: - 1 byte: flag - 1-5 bytes: key length (only if FLAG_SAME_KEY_LENGTH is not set in flag) - 1-5 bytes: value length (only if FLAG_SAME_VALUE_LENGTH is not set in flag) - 1-5 bytes: prefix length - ...
DiffKeyDeltaEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
 
DiffKeyDeltaEncoder.DiffCompressionState - Class in org.apache.hadoop.hbase.io.encoding
 
DiffKeyDeltaEncoder.DiffCompressionState() - Constructor for class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffCompressionState
 
DiffKeyDeltaEncoder.DiffSeekerState - Class in org.apache.hadoop.hbase.io.encoding
 
DiffKeyDeltaEncoder.DiffSeekerState() - Constructor for class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffSeekerState
 
DirectMemoryUtils - Class in org.apache.hadoop.hbase.util
Utilities for interacting with and monitoring DirectByteBuffer allocations.
DirectMemoryUtils() - Constructor for class org.apache.hadoop.hbase.util.DirectMemoryUtils
 
DirScanPool - Class in org.apache.hadoop.hbase.master.cleaner
The thread pool used for scan directories
DirScanPool(Configuration) - Constructor for class org.apache.hadoop.hbase.master.cleaner.DirScanPool
 
disable(HTableDescriptor) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Turn off processing constraints for a given table, even if constraints have been turned on or added.
disableConstraint(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Disable the given Constraint.
DISABLED - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
 
DISABLED_ZNODE_BYTES - Static variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
DisabledRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
A RegionSplitPolicy that disables region splits.
DisabledRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy
 
DisabledTableSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
Take a snapshot of a disabled table.
DisabledTableSnapshotHandler(HBaseProtos.SnapshotDescription, MasterServices, SnapshotManager) - Constructor for class org.apache.hadoop.hbase.master.snapshot.DisabledTableSnapshotHandler
 
disableHFileBackup(String) - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
Disable hfile backups for the given table.
disableHFileBackup(byte[]) - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
Disable hfile backups for the given table.
disableHFileBackup() - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
Disable hfile backups for all tables.
disableJSON() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
turns JSON output off, and turns on "pretty strings" for human consumption
disablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Stop the replication stream to the specified peer.
disablePeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Stop the replication to the specified remote slave cluster.
disablePeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
disableStatusJournal() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
disableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Disable table and wait on completion.
disableTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Disable table and wait on completion.
disableTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTable(TableName, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
disableTable(RpcController, MasterProtos.DisableTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
disableTable(TableName, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Disable an existing table
disableTable(ByteBuffer, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
disableTable(ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
disableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
disableTable(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Disables a table (takes it off-line) If it is being served, the master will tell the servers to stop serving it.
disableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
disableTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Starts the disable of a table.
disableTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Starts the disable of a table.
disableTableAsync(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTableAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
DisableTableHandler - Class in org.apache.hadoop.hbase.master.handler
Handler to run disable of a table.
DisableTableHandler(Server, TableName, AssignmentManager, TableLockManager, boolean) - Constructor for class org.apache.hadoop.hbase.master.handler.DisableTableHandler
 
DisableTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
 
DisableTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
DisableTableProcedure(MasterProcedureEnv, TableName, boolean) - Constructor for class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
Constructor
DisableTableProcedure(MasterProcedureEnv, TableName, boolean, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
Constructor
disableTableRep(TableName) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Disable a table's replication switch.
disableTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Disable tables matching the passed in pattern and wait on completion.
disableTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Disable tables matching the passed in pattern and wait on completion.
disableTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Disable tables matching the passed in pattern and wait on completion.
disableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Disable tables matching the passed in pattern and wait on completion.
disableValues() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
turns value output off
DISALLOW_WRITES_IN_RECOVERING - Static variable in class org.apache.hadoop.hbase.HConstants
 
discardCurrentRowNode(boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
disconnect() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
disconnectSince() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
Check if the caller who made this IPC call has disconnected.
disconnectSince() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
 
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutor
 
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
Add the request to the executor queue
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Dispatches an RPC request asynchronously.
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
DispatchMergingRegionHandler - Class in org.apache.hadoop.hbase.master.handler
Handles MERGE regions request on master: move the regions together(on the same regionserver) and send MERGE RPC to regionserver.
DispatchMergingRegionHandler(MasterServices, CatalogJanitor, HRegionInfo, HRegionInfo, boolean, User) - Constructor for class org.apache.hadoop.hbase.master.handler.DispatchMergingRegionHandler
 
dispatchMergingRegions(HRegionInfo, HRegionInfo, boolean, User) - Method in class org.apache.hadoop.hbase.master.HMaster
 
dispatchMergingRegions(RpcController, MasterProtos.DispatchMergingRegionsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
dispatchMergingRegions(HRegionInfo, HRegionInfo, boolean, User) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Merge two regions.
dispose() - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
Release resources used by wrapped saslClient
DISTRIBUTED_LOG_REPLAY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key that enables unflushed WAL edits directly being replayed to region servers
distributedLogReplay - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
 
divideForAvg(BigDecimal, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
divideForAvg(Double, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
divideForAvg(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
divideForAvg(S, Long) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
used for computing average of <S> data values.
DNS - Class in org.apache.hadoop.hbase.util
Wrapper around Hadoop's DNS class to hide reflection.
doAction(BaseLoadBalancer.Cluster.Action) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
 
doAsUser - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
 
doBulkLoad(Path, HTable) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
Deprecated.
since hbase-1.3.0, hbase-1.2.2, and hbase-1.1.6; replaced by LoadIncrementalHFiles.doBulkLoad(Path, Admin, Table, RegionLocator).
doBulkLoad(Path, Admin, Table, RegionLocator) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
Perform a bulk load of the given directory into the given pre-existing table.
doCompare(CompareFilter.CompareOp, ByteArrayComparable, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
doesNamespaceExist(String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
doExecute(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Internal method called by the ProcedureExecutor that starts the user-level code execute().
doExecute(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.SequentialProcedure
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.ClickjackingPreventionFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.NoCacheFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.AdminAuthorizedServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.conf.ConfServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.HttpServer.StackServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
Process a GET request for the specified resource.
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.log.LogLevel.Servlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.ProfileOutputServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.ProfileServlet.DisabledServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.ProfileServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.master.HMaster.RedirectServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.master.MasterDumpServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.master.MasterStatusServlet
 
doGet(Connection, Get) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
doGet(Connection, List<Get>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.regionserver.RSDumpServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.regionserver.RSStatusServlet
 
doLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.client.Query
Get the logical value indicating whether on-demand CF loading should be allowed.
doMain(String[]) - Method in class org.apache.hadoop.hbase.util.ServerCommandLine
Parse and run the given command line.
domainNamePointerToHostName(String) - Static method in class org.apache.hadoop.hbase.util.Strings
Given a PTR string generated via reverse DNS lookup, return everything except the trailing period.
done - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
 
done() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
 
done() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
Done when there are no more columns to match against.
done() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
We can never know a-priori if we are done, so always return false.
done - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
doneBulkLoad(byte[], String) - Method in interface org.apache.hadoop.hbase.regionserver.Region.BulkLoadListener
Called after a successful HFile load
doneWithColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
This method is used to inform the column tracker that we are done with this column.
DoNotRetryIOException - Exception in org.apache.hadoop.hbase
Subclass if exception is not meant to be retried: e.g.
DoNotRetryIOException() - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryIOException(String) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryRegionException - Exception in org.apache.hadoop.hbase.client
Similar to RegionException, but disables retries.
DoNotRetryRegionException() - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
 
DoNotRetryRegionException(String) - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
 
DONT_BREAK_LINES - Static variable in class org.apache.hadoop.hbase.util.Base64
Don't break lines when encoding (violates strict Base64 specification)
DONT_FILL_HEADER - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
 
doRealSeek(KeyValueScanner, Cell, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
 
doRegionCompactionPrep() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
doResizeIfNecessary() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
doResizeIfNecessary() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
 
doResizeIfNecessary() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
doResizeIfNecessary() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
 
doRollback(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Internal method called by the ProcedureExecutor that starts the user-level code rollback().
doRollback(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.SequentialProcedure
 
doSetup(Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context, Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
Handles common parameter initialization that a subclass might want to leverage.
doSetup(Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
Handles common parameter initialization that a subclass might want to leverage.
doSetup(Mapper<LongWritable, Text, ImmutableBytesWritable, Text>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
Handles common parameter initialization that a subclass might want to leverage.
doSmokeTest(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
 
doStart() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
doStart() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
 
doStaticMain(String[]) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
Call this from the concrete tool class's main function.
doStop() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
doStop() - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
 
doStop() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
 
DoubleColumnInterpreter - Class in org.apache.hadoop.hbase.client.coprocessor
a concrete column interpreter implementation.
DoubleColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
doubleEquals(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
doubleEquals(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
doubleValue() - Method in class org.apache.hadoop.hbase.util.LongAdder
Returns the LongAdder.sum() as a double after a widening primitive conversion.
doWork() - Method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
 
doWork() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
The "main function" of the tool
DrainBarrier - Class in org.apache.hadoop.hbase.util
A simple barrier that can be used by classes that need to wait for some operations to finish before stopping/closing/etc.
DrainBarrier() - Constructor for class org.apache.hadoop.hbase.util.DrainBarrier
 
DrainingServerTracker - Class in org.apache.hadoop.hbase.zookeeper
Tracks the list of draining region servers via ZK.
DrainingServerTracker(ZooKeeperWatcher, Abortable, ServerManager) - Constructor for class org.apache.hadoop.hbase.zookeeper.DrainingServerTracker
 
drainingZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
drainInputStreamToBuffer(InputStream) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copy from the InputStream to a new heap ByteBuffer until the InputStream is exhausted.
drainTo(Collection<? super CallRunner>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
drainTo(Collection<? super CallRunner>, int) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
drainTo(Collection<? super Runnable>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
drainTo(Collection<? super Runnable>, int) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
drainTo(Collection<? super E>) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
drainTo(Collection<? super E>, int) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
drillDown(Record) - Method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
 
drillDown(Record) - Method in class org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy
 
drillDown(Record) - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
 
drillDown(Record) - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
 
drillDown(Record) - Method in class org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy
 
drillDown(Record) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
drillDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
DrillDownInfo - Class in org.apache.hadoop.hbase.hbtop.mode
Information about drilling down.
DrillDownInfo(Mode, List<RecordFilter>) - Constructor for class org.apache.hadoop.hbase.hbtop.mode.DrillDownInfo
 
Driver - Class in org.apache.hadoop.hbase.mapred
Driver for hbase mapreduce jobs.
Driver() - Constructor for class org.apache.hadoop.hbase.mapred.Driver
 
Driver - Class in org.apache.hadoop.hbase.mapreduce
Driver for hbase mapreduce jobs.
Driver() - Constructor for class org.apache.hadoop.hbase.mapreduce.Driver
 
drop() - Method in class org.apache.hadoop.hbase.ipc.CallRunner
When we want to drop this call because of server is overloaded.
DropDeletesCompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
A query matcher for compaction which can drop delete markers.
DropDeletesCompactionScanQueryMatcher(ScanInfo, DeleteTracker, long, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.DropDeletesCompactionScanQueryMatcher
 
dropDependentColumn - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
dropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
DroppedSnapshotException - Exception in org.apache.hadoop.hbase
Thrown during flush if the possibility snapshot content was not properly persisted into store files.
DroppedSnapshotException() - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
 
DroppedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
 
DropwizardMeter - Class in org.apache.hadoop.hbase.metrics.impl
Dropwizard metrics implementation of Meter.
DropwizardMeter() - Constructor for class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
 
DropwizardMeter(Meter) - Constructor for class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
 
DRY_RUN_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
dump() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
dump() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
dump() - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
 
dump(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
dumpAllBeans() - Static method in class org.apache.hadoop.hbase.util.JSONBean
Dump out all registered mbeans as json on System.out.
dumpAsText(PrintWriter) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
dumpExecutors(ExecutorService, PrintWriter) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
 
dumpOverlapProblems(Multimap<byte[], HBaseFsck.HbckInfo>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
dumpPeersState(ReplicationAdmin, Map<String, ReplicationPeerConfig>) - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
 
dumpQueue() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
dumpQueue(HRegionServer, PrintWriter) - Static method in class org.apache.hadoop.hbase.regionserver.RSDumpServlet
 
dumpQueues(ClusterConnection, Set<String>, ZooKeeperWatcher, boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
 
dumpRegionServerMetrics() - Static method in class org.apache.hadoop.hbase.util.JSONBean
Dump out a subset of regionserver mbeans only, not all of them, as json on System.out.
DumpReplicationQueues - Class in org.apache.hadoop.hbase.replication.regionserver
Provides information about the existing states of replication, replication peers and queues.
DumpReplicationQueues() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
 
dumpReplicationSummary() - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
 
dumpRowLock(HRegionServer, PrintWriter) - Static method in class org.apache.hadoop.hbase.regionserver.RSDumpServlet
 
dumpSidelinedRegions(Map<Path, HBaseFsck.HbckInfo>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
dumpTailOfLogs(PrintWriter, long) - Static method in class org.apache.hadoop.hbase.monitoring.LogMonitoring
 
dumpTo(Writer, String) - Method in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorStatus
Dump a textual representation of the executor's status to the given writer.
dumpTo(PrintWriter) - Method in class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
Dump the contents of the buffer to the given stream.
dumpVersionInfo(PrintWriter) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
 
Durability - Enum in org.apache.hadoop.hbase.client
Enum describing the durability guarantees for tables and Mutations Note that the items must be sorted in order of increasing durability
durability - Variable in class org.apache.hadoop.hbase.client.Mutation
 
DURABILITY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Durability setting for the table.
durability - Variable in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
durability - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
durability - Variable in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
durability - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
DynamicClassLoader - Class in org.apache.hadoop.hbase.util
This is a class loader that can load classes dynamically from new jar files under a configured folder.
DynamicClassLoader(Configuration, ClassLoader) - Constructor for class org.apache.hadoop.hbase.util.DynamicClassLoader
Creates a DynamicClassLoader that can load classes dynamically from jar files under a specific folder.
DynamicMetricsRegistry - Class in org.apache.hadoop.metrics2.lib
An optional metrics registry class for creating and maintaining a collection of MetricsMutables, making writing metrics source easier.
DynamicMetricsRegistry(String) - Constructor for class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Construct the registry with a record name
DynamicMetricsRegistry(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Construct the registry with a metadata object

E

E - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'E'
EARLIEST_PUT_TS - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Key for timestamp of earliest-put in metadata
earliestPutTs - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
Earliest put timestamp if major compaction
earliestPutTs - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.DropDeletesCompactionScanQueryMatcher
Oldest put in any of the involved store files Used to decide whether it is ok to delete family delete marker of this store keeps deleted KVs.
earliestPutTs - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.LegacyScanQueryMatcher
Deprecated.
Oldest put in any of the involved store files Used to decide whether it is ok to delete family delete marker of this store keeps deleted KVs.
edit - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
editRegion(HRegionInfo) - Method in interface org.apache.hadoop.hbase.util.ModifyRegionUtils.RegionEditTask
 
editRegions(ThreadPoolExecutor, Collection<HRegionInfo>, ModifyRegionUtils.RegionEditTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
Execute the task on the specified set of regions.
elapsedTime() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
element() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
element() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
EMPTY_BYTE_ARRAY - Static variable in class org.apache.hadoop.hbase.HConstants
An empty instance.
EMPTY_END_ROW - Static variable in class org.apache.hadoop.hbase.HConstants
Last row in a table.
EMPTY_HEADER_ARRAY - Static variable in class org.apache.hadoop.hbase.rest.client.Client
 
EMPTY_REPLICATIONLOAD - Static variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
 
EMPTY_RESULT - Static variable in class org.apache.hadoop.hbase.client.Result
 
EMPTY_SERVER_LIST - Static variable in class org.apache.hadoop.hbase.ServerName
 
EMPTY_SERVERLOAD - Static variable in class org.apache.hadoop.hbase.ServerLoad
 
EMPTY_START_ROW - Static variable in class org.apache.hadoop.hbase.HConstants
Used by scanners, etc when they want to start at the beginning of a region
EMPTY_UUIDS - Static variable in class org.apache.hadoop.hbase.wal.WALKey
 
EMPTY_WALEDIT - Static variable in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
emptyCompressionContext - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
EmptyNormalizationPlan - Class in org.apache.hadoop.hbase.master.normalizer
Plan which signifies that no normalization is required, or normalization of this table isn't allowed, this is singleton.
EmptyServiceNameException - Exception in org.apache.hadoop.hbase.ipc
 
EmptyServiceNameException() - Constructor for exception org.apache.hadoop.hbase.ipc.EmptyServiceNameException
 
EmptyWatcher - Class in org.apache.hadoop.hbase.zookeeper
An empty ZooKeeper watcher
enable(HTableDescriptor) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Enable constraints on a table.
ENABLE_CLIENT_BACKPRESSURE - Static variable in class org.apache.hadoop.hbase.HConstants
Config key for if the server should send backpressure and if the client should listen to that backpressure from the server
ENABLE_DATA_FILE_UMASK - Static variable in class org.apache.hadoop.hbase.HConstants
Enable file permission modification from standard hbase
ENABLE_WAL_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration name of WAL Compression
ENABLE_WAL_ENCRYPTION - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for enabling WAL encryption, a boolean
enableCatalogJanitor(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable/Disable the catalog janitor
enableCatalogJanitor(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Enable/Disable the catalog janitor
enableCatalogJanitor(RpcController, MasterProtos.EnableCatalogJanitorRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
enableConstraint(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Enable the given Constraint.
enabled(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Check to see if the given constraint is enabled.
ENABLED_ZNODE_BYTES - Static variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
EnabledTableSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
Handle the master side of taking a snapshot of an online table, regardless of snapshot type.
EnabledTableSnapshotHandler(HBaseProtos.SnapshotDescription, MasterServices, SnapshotManager) - Constructor for class org.apache.hadoop.hbase.master.snapshot.EnabledTableSnapshotHandler
 
enableHFileBackupAsync(byte[]) - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
Turn on backups for all HFiles for the given table.
enableJSON() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
turns JSON output on
enablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Restart the replication stream to the specified peer.
enablePeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Restart the replication to the specified remote slave cluster.
enablePeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
enableStatusJournal(boolean) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
Enable journal that will store all statuses that have been set along with the time stamps when they were set.
enableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable a table.
enableTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Enable a table.
enableTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTable(TableName, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
enableTable(RpcController, MasterProtos.EnableTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
enableTable(TableName, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Enable an existing table
enableTable(ByteBuffer, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
enableTable(ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
enableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
enableTable(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Brings a table on-line (enables it)
enableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
enableTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Brings a table on-line (enables it).
enableTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Brings a table on-line (enables it).
enableTableAsync(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTableAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
EnableTableHandler - Class in org.apache.hadoop.hbase.master.handler
Handler to run enable of a table.
EnableTableHandler(Server, TableName, AssignmentManager, TableLockManager, boolean) - Constructor for class org.apache.hadoop.hbase.master.handler.EnableTableHandler
 
EnableTableHandler(MasterServices, TableName, AssignmentManager, TableLockManager, boolean) - Constructor for class org.apache.hadoop.hbase.master.handler.EnableTableHandler
 
EnableTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
 
EnableTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
EnableTableProcedure(MasterProcedureEnv, TableName, boolean) - Constructor for class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
Constructor
EnableTableProcedure(MasterProcedureEnv, TableName, boolean, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
Constructor
enableTableRep(TableName) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Enable a table's replication switch.
enableTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable tables matching the passed in pattern and wait on completion.
enableTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable tables matching the passed in pattern and wait on completion.
enableTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Enable tables matching the passed in pattern and wait on completion.
enableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Enable tables matching the passed in pattern and wait on completion.
enableTestingStats() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
 
enableValues() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
turns value output on
encode(Cell, HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
Deprecated.
 
encode(Cell, HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Encodes a KeyValue.
encode(Cell, HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
 
encode(Cell, HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Encodes a KeyValue.
encode(Cell, HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
encode(Cell, HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
encode(PositionedByteRange, T) - Method in interface org.apache.hadoop.hbase.types.DataType
Write instance val into buffer dst.
encode(PositionedByteRange, T) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
Write a subset of val to dst.
encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
Write a subset of val to buff.
encode(PositionedByteRange, Float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
encode(PositionedByteRange, Double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
encode(PositionedByteRange, Short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
encode(PositionedByteRange, Integer) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
encode(PositionedByteRange, Long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
encode(PositionedByteRange, Byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
encode(PositionedByteRange, Number) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
encode(PositionedByteRange, String) - Method in class org.apache.hadoop.hbase.types.OrderedString
 
encode(PositionedByteRange, CellProtos.Cell) - Method in class org.apache.hadoop.hbase.types.PBCell
 
encode(PositionedByteRange, Byte) - Method in class org.apache.hadoop.hbase.types.RawByte
 
encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.RawBytes
 
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytes
Write val into dst, respecting voff and vlen.
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytesFixedLength
Write val into buff, respecting offset and length.
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytesTerminated
Write val into dst, respecting offset and length.
encode(PositionedByteRange, Double) - Method in class org.apache.hadoop.hbase.types.RawDouble
 
encode(PositionedByteRange, Float) - Method in class org.apache.hadoop.hbase.types.RawFloat
 
encode(PositionedByteRange, Integer) - Method in class org.apache.hadoop.hbase.types.RawInteger
 
encode(PositionedByteRange, Long) - Method in class org.apache.hadoop.hbase.types.RawLong
 
encode(PositionedByteRange, Short) - Method in class org.apache.hadoop.hbase.types.RawShort
 
encode(PositionedByteRange, String) - Method in class org.apache.hadoop.hbase.types.RawString
 
encode(PositionedByteRange, Object[]) - Method in class org.apache.hadoop.hbase.types.Struct
 
encode(PositionedByteRange, T) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
Write instance val into buffer dst.
ENCODE - Static variable in class org.apache.hadoop.hbase.util.Base64
Specify encoding.
encode3to4(byte[], byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Encodes up to the first three bytes of array threeBytes and returns a four-byte array in Base64 notation.
encode3to4(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Encodes up to three bytes of the array source and writes the resulting four Base64 bytes to destination.
ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
encodeBlobCopy(PositionedByteRange, byte[], int, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a Blob value as a byte-for-byte copy.
encodeBlobCopy(PositionedByteRange, byte[], Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a Blob value as a byte-for-byte copy.
encodeBlobVar(PositionedByteRange, byte[], int, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a Blob value using a modified varint encoding scheme.
encodeBlobVar(PositionedByteRange, byte[], Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a blob value using a modified varint encoding scheme.
encodeByte(PositionedByteRange, byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
Write instance val into buffer dst.
encodeByte(byte[], int, byte) - Method in class org.apache.hadoop.hbase.types.RawByte
Write instance val into buffer buff.
encodeBytes(byte[]) - Static method in class org.apache.hadoop.hbase.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Encodes a byte array into Base64 notation.
ENCODED_REGION_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.HRegionInfo
A non-capture group so that this can be embedded.
encodeData() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
Do the encoding, but do not cache the encoded data.
encodedBlockSizeWritten() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
Returns the number of bytes written into the current block so far, or zero if not writing the block at the moment.
encodedClass() - Method in interface org.apache.hadoop.hbase.types.DataType
Inform consumers over what type this DataType operates.
encodedClass() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedString
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.PBCell
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawByte
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawLong
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawShort
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawString
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.Struct
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.Union2
 
EncodedDataBlock - Class in org.apache.hadoop.hbase.io.encoding
Encapsulates a data block compressed using a particular encoding algorithm.
EncodedDataBlock(DataBlockEncoder, DataBlockEncoding, byte[], HFileContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
Create a buffer which will be encoded using dataBlockEncoder.
encodedLength(T) - Method in interface org.apache.hadoop.hbase.types.DataType
Inform consumers how long the encoded byte[] will be.
encodedLength(T) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
encodedLength(Float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
encodedLength(Double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
encodedLength(Short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
encodedLength(Integer) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
encodedLength(Long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
encodedLength(Byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
encodedLength(Number) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
encodedLength(String) - Method in class org.apache.hadoop.hbase.types.OrderedString
 
encodedLength(T) - Method in class org.apache.hadoop.hbase.types.PBType
 
encodedLength(Byte) - Method in class org.apache.hadoop.hbase.types.RawByte
 
encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.RawBytes
 
encodedLength(Double) - Method in class org.apache.hadoop.hbase.types.RawDouble
 
encodedLength(Float) - Method in class org.apache.hadoop.hbase.types.RawFloat
 
encodedLength(Integer) - Method in class org.apache.hadoop.hbase.types.RawInteger
 
encodedLength(Long) - Method in class org.apache.hadoop.hbase.types.RawLong
 
encodedLength(Short) - Method in class org.apache.hadoop.hbase.types.RawShort
 
encodedLength(String) - Method in class org.apache.hadoop.hbase.types.RawString
 
encodedLength(Object[]) - Method in class org.apache.hadoop.hbase.types.Struct
 
encodedLength(T) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
encodeDouble(PositionedByteRange, double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
Write instance val into buffer dst.
encodeDouble(PositionedByteRange, double) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Write instance val into buffer dst.
encodeDouble(byte[], int, double) - Method in class org.apache.hadoop.hbase.types.RawDouble
Write instance val into buffer buff.
encodedRegionName - Variable in class org.apache.hadoop.hbase.wal.WALKey
 
encodeFloat(PositionedByteRange, float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
Write instance val into buffer buff.
encodeFloat(byte[], int, float) - Method in class org.apache.hadoop.hbase.types.RawFloat
Write instance val into buffer buff.
encodeFloat32(PositionedByteRange, float, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a 32-bit floating point value using the fixed-length encoding.
encodeFloat64(PositionedByteRange, double, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a 64-bit floating point value using the fixed-length encoding.
encodeFromFile(String) - Static method in class org.apache.hadoop.hbase.util.Base64
Convenience method for reading a binary file and base64-encoding it.
encodeInt(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
Write instance val into buffer dst.
encodeInt(byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawInteger
Write instance val into buffer buff.
encodeInt16(PositionedByteRange, short, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int16 value using the fixed-length encoding.
encodeInt32(PositionedByteRange, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int32 value using the fixed-length encoding.
encodeInt64(PositionedByteRange, long, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int64 value using the fixed-length encoding.
encodeInt8(PositionedByteRange, byte, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int8 value using the fixed-length encoding.
encodeLong(PositionedByteRange, long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
Write instance val into buffer dst.
encodeLong(PositionedByteRange, long) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Write instance val into buffer dst.
encodeLong(byte[], int, long) - Method in class org.apache.hadoop.hbase.types.RawLong
Write instance val into buffer buff.
encodeNull(PositionedByteRange, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a null value.
encodeNumeric(PositionedByteRange, long, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a numerical value using the variable-length encoding.
encodeNumeric(PositionedByteRange, double, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a numerical value using the variable-length encoding.
encodeNumeric(PositionedByteRange, BigDecimal, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a numerical value using the variable-length encoding.
EncoderBufferTooSmallException - Exception in org.apache.hadoop.hbase.io.encoding
Internal error which indicates a bug in a data block encoding algorithm.
EncoderBufferTooSmallException(String) - Constructor for exception org.apache.hadoop.hbase.io.encoding.EncoderBufferTooSmallException
 
encodeRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
EncoderFactory - Class in org.apache.hadoop.hbase.codec.prefixtree.encode
Retrieve PrefixTreeEncoders from this factory which handles pooling them and preparing the ones retrieved from the pool for usage.
EncoderFactory() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderFactory
 
EncoderPool - Interface in org.apache.hadoop.hbase.codec.prefixtree.encode
 
EncoderPoolImpl - Class in org.apache.hadoop.hbase.codec.prefixtree.encode
 
EncoderPoolImpl() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderPoolImpl
 
encodeShort(PositionedByteRange, short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
Write instance val into buffer dst.
encodeShort(byte[], int, short) - Method in class org.apache.hadoop.hbase.types.RawShort
Write instance val into buffer buff.
encodeString(PositionedByteRange, String, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a String value.
encodeVisibilityForReplication(List<Tag>, Byte) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
encodeVisibilityForReplication(List<Tag>, Byte) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
Provides a way to modify the visibility tags of type TagType .VISIBILITY_TAG_TYPE, that are part of the cell created from the WALEdits that are prepared for replication while calling ReplicationEndpoint .replicate().
EncodingState - Class in org.apache.hadoop.hbase.io.encoding
Keeps track of the encoding state.
EncodingState() - Constructor for class org.apache.hadoop.hbase.io.encoding.EncodingState
 
encrypt(OutputStream, byte[], int, int, Encryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a block of plaintext
encrypt(OutputStream, byte[], int, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a block of plaintext
encrypt(OutputStream, InputStream, Encryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a stream of plaintext given an encryptor
encrypt(OutputStream, InputStream, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a stream of plaintext given a context and IV
ENCRYPTION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
Encryption - Class in org.apache.hadoop.hbase.io.crypto
A facade for encryption algorithms and related support.
Encryption.Context - Class in org.apache.hadoop.hbase.io.crypto
Crypto context
ENCRYPTION_KEY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
EncryptionTest - Class in org.apache.hadoop.hbase.util
 
EncryptionUtil - Class in org.apache.hadoop.hbase.security
Some static utility methods for encryption uses in hbase-client.
EncryptionUtil() - Constructor for class org.apache.hadoop.hbase.security.EncryptionUtil
 
Encryptor - Interface in org.apache.hadoop.hbase.io.crypto
Encryptors apply a cipher to an OutputStream to produce ciphertext.
encryptWithSubjectKey(OutputStream, InputStream, String, Configuration, Cipher, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypts a block of plaintext with the symmetric key resolved for the given subject
end() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
end() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
END - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
Deprecated.
END_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
Deprecated.
 
END_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
endBlockEncoding(HFileBlockEncodingContext, DataOutputStream, byte[]) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
Deprecated.
 
endBlockEncoding(HFileBlockEncodingContext, DataOutputStream, byte[]) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Ends encoding for a block of KeyValues.
endBlockEncoding(HFileBlockEncodingContext, DataOutputStream, byte[]) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
 
endBlockEncoding(HFileBlockEncodingContext, DataOutputStream, byte[], BlockType) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Ends encoding for a block of KeyValues.
endBlockEncoding(HFileBlockEncodingContext, DataOutputStream, byte[], BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
endBlockEncoding(HFileBlockEncodingContext, DataOutputStream, byte[], BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
endKey - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
endKey - Variable in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
ENDKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
endMillis() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionWindow
Exclusive upper bound
endOfLine() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
endOfLine(int, int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
 
endOfLine() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
 
endOfLine() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
endOp() - Method in class org.apache.hadoop.hbase.util.DrainBarrier
Ends the operation.
endOperation(long, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
Ends the operation started by startOperation.
endPersistentOutput() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
ends output of a single, persistent list.
EndpointObserver - Interface in org.apache.hadoop.hbase.coprocessor
Coprocessors implement this interface to observe and mediate endpoint invocations on a region.
ENDROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
endTask(SplitLogTask, AtomicLong, SplitLogWorkerCoordination.SplitTaskDetails) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
Notify coordination engine that splitting task has completed.
endTask(SplitLogTask, AtomicLong, SplitLogWorkerCoordination.SplitTaskDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
endTask() can fail and the only way to recover out of it is for the SplitLogManager to timeout the task node.
ENDTIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
enforceSeek() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Does the real seek operation in case it was skipped by seekToRowCol(KeyValue, boolean) (TODO: Whats this?).
enforceSeek() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
 
enforceSeek() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
EnforcingScanLabelGenerator - Class in org.apache.hadoop.hbase.security.visibility
This ScanLabelGenerator enforces a set of predefined authorizations for a given user, the set defined by the admin using the VisibilityClient admin interface or the set_auths shell command.
EnforcingScanLabelGenerator() - Constructor for class org.apache.hadoop.hbase.security.visibility.EnforcingScanLabelGenerator
 
enqueueLog(Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
enqueueLog(Path) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
Add a log to the list of logs to replicate
ENSEMBLE_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
The name of the ensemble table
ensureArraySearcherValid(ByteBuffer, PrefixTreeArraySearcher, boolean) - Static method in class org.apache.hadoop.hbase.codec.prefixtree.decode.DecoderFactory
helper
ensureKeyValue(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Deprecated.
without any replacement.
ensureKeyValues(List<Cell>) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Deprecated.
ensureKeyValueTypeForMR(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Deprecated.
without any replacement.
ensureMetaWALRoller() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
We initialize the roller for the wal that handles meta lazily since we don't know if this regionserver will handle it.
ensureNamespaceExists(String) - Method in class org.apache.hadoop.hbase.master.HMaster
Ensure that the specified namespace exists, otherwise throws a NamespaceNotFoundException
ensureNonEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
Verifies that the block index is non-empty and throws an IllegalStateException otherwise.
ensurePerCellCapacities() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
Check that the arrays used to hold cell fragments are large enough for the cell that is being added.
ensureSingleLevel() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
 
entry(Field, Object) - Static method in class org.apache.hadoop.hbase.hbtop.Record
 
entry(Field, FieldValue) - Static method in class org.apache.hadoop.hbase.hbtop.Record
 
entryBuffers - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
entryCount - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Total # of key/value entries, i.e.
entryLruList() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Debugging function that returns a List sorted by access time.
entrySet() - Method in class org.apache.hadoop.hbase.hbtop.Record
 
entrySet() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
entrySet() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
entrySet() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
entrySet() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
entryTableSet() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Debugging function that returns a Set of all entries in the hash table.
enumForId(short) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
EnvironmentEdge - Interface in org.apache.hadoop.hbase.util
Has some basic interaction with the environment.
EnvironmentEdgeManager - Class in org.apache.hadoop.hbase.util
Manages a singleton instance of the environment edge.
equal(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
equal(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
EQUAL_TO - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for equal to (=)
EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
EQUAL_TO Array
EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
equals(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
equals
equals(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
equals
equals(Object) - Method in class org.apache.hadoop.hbase.client.Action
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.Get
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.Increment
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.RowMutations
 
equals(Object) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
equals(Object) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayReversibleScanner
Object methods
equals(Object) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
Object methods
equals(Object) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
Object methods
equals(Object) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
equals(Object) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
Generated by Eclipse
equals(Object) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
equals(Object) - Method in class org.apache.hadoop.hbase.hbtop.field.Size
 
equals(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
equals(Object) - Method in class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
 
equals(Object) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
equals(Object) - Method in class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
 
equals(Object) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
equals(Object) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.HRegionLocation
 
equals(Object) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Compare the contents of the descriptor with another one passed as a parameter.
equals(Object) - Method in class org.apache.hadoop.hbase.io.FileLink
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.Reference
 
equals(Object) - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
equals(Object) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
equals(Object) - Method in class org.apache.hadoop.hbase.KeyValue
Needed doing 'contains' on List.
equals(Object) - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
equals(Object) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
equals(Object) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
 
equals(Object) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
 
equals(Object) - Method in class org.apache.hadoop.hbase.master.RegionPlan
 
equals(Object) - Method in class org.apache.hadoop.hbase.master.RegionState
Check if two states are the same, except timestamp
equals(Object) - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.net.Address
 
equals(Object) - Method in class org.apache.hadoop.hbase.procedure.ProcedureManager
 
equals(Object) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns true is the specified entry has the same key and the same value as this entry.
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.access.Permission
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.access.UserPermission
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.User
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
 
equals(Object) - Method in class org.apache.hadoop.hbase.ServerLoad
 
equals(Object) - Method in class org.apache.hadoop.hbase.ServerName
 
equals(Object) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
equals(Object) - Method in class org.apache.hadoop.hbase.TableName
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
 
equals(Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
equals(AlreadyExists) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
equals(BatchMutation) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
equals(ColumnDescriptor) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
equals(Hbase.append_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
equals(Hbase.append_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
equals(Hbase.atomicIncrement_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
equals(Hbase.atomicIncrement_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
equals(Hbase.checkAndPut_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
equals(Hbase.checkAndPut_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
equals(Hbase.compact_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
equals(Hbase.compact_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
equals(Hbase.createTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
equals(Hbase.createTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
equals(Hbase.deleteAll_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
equals(Hbase.deleteAll_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
equals(Hbase.deleteAllRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
equals(Hbase.deleteAllRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
equals(Hbase.deleteAllRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
equals(Hbase.deleteAllRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
equals(Hbase.deleteAllTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
equals(Hbase.deleteAllTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
equals(Hbase.deleteTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
equals(Hbase.deleteTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
equals(Hbase.disableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
equals(Hbase.disableTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
equals(Hbase.enableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
equals(Hbase.enableTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
equals(Hbase.get_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
equals(Hbase.get_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
equals(Hbase.getColumnDescriptors_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
equals(Hbase.getColumnDescriptors_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
equals(Hbase.getRegionInfo_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
equals(Hbase.getRegionInfo_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
equals(Hbase.getRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
equals(Hbase.getRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
equals(Hbase.getRowOrBefore_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
equals(Hbase.getRowOrBefore_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
equals(Hbase.getRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
equals(Hbase.getRows_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
equals(Hbase.getRowsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
equals(Hbase.getRowsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
equals(Hbase.getRowsWithColumns_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
equals(Hbase.getRowsWithColumns_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
equals(Hbase.getRowsWithColumnsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
equals(Hbase.getRowsWithColumnsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
equals(Hbase.getRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
equals(Hbase.getRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
equals(Hbase.getRowWithColumns_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
equals(Hbase.getRowWithColumns_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
equals(Hbase.getRowWithColumnsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
equals(Hbase.getRowWithColumnsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
equals(Hbase.getTableNames_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
equals(Hbase.getTableNames_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
equals(Hbase.getTableRegions_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
equals(Hbase.getTableRegions_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
equals(Hbase.getVer_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
equals(Hbase.getVer_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
equals(Hbase.getVerTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
equals(Hbase.getVerTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
equals(Hbase.increment_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
equals(Hbase.increment_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
equals(Hbase.incrementRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
equals(Hbase.incrementRows_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
equals(Hbase.isTableEnabled_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
equals(Hbase.isTableEnabled_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
equals(Hbase.majorCompact_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
equals(Hbase.majorCompact_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
equals(Hbase.mutateRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
equals(Hbase.mutateRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
equals(Hbase.mutateRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
equals(Hbase.mutateRows_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
equals(Hbase.mutateRowsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
equals(Hbase.mutateRowsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
equals(Hbase.mutateRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
equals(Hbase.mutateRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
equals(Hbase.scannerClose_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
equals(Hbase.scannerClose_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
equals(Hbase.scannerGet_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
equals(Hbase.scannerGet_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
equals(Hbase.scannerGetList_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
equals(Hbase.scannerGetList_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
equals(Hbase.scannerOpen_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
equals(Hbase.scannerOpen_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
equals(Hbase.scannerOpenTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
equals(Hbase.scannerOpenTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
equals(Hbase.scannerOpenWithPrefix_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
equals(Hbase.scannerOpenWithPrefix_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
equals(Hbase.scannerOpenWithScan_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
equals(Hbase.scannerOpenWithScan_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
equals(Hbase.scannerOpenWithStop_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
equals(Hbase.scannerOpenWithStop_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
equals(Hbase.scannerOpenWithStopTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
equals(Hbase.scannerOpenWithStopTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
equals(Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
equals(IllegalArgument) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
equals(Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
equals(IOError) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
equals(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
equals(TAppend) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
equals(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
equals(TColumn) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
equals(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
equals(TRegionInfo) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
equals(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
equals(TScan) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
equals(Object) - Method in exception org.apache.hadoop.hbase.thrift.ThriftServerRunner.IOErrorWithCause
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
equals(TAppend) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
equals(TAuthorization) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
equals(TCellVisibility) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
equals(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
equals(TColumnIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
equals(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
equals(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
equals(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
equals(THBaseService.append_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
equals(THBaseService.append_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
equals(THBaseService.checkAndDelete_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
equals(THBaseService.checkAndDelete_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
equals(THBaseService.checkAndMutate_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
equals(THBaseService.checkAndMutate_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
equals(THBaseService.checkAndPut_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
equals(THBaseService.checkAndPut_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
equals(THBaseService.closeScanner_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
equals(THBaseService.closeScanner_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
equals(THBaseService.deleteMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
equals(THBaseService.deleteMultiple_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
equals(THBaseService.deleteSingle_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
equals(THBaseService.deleteSingle_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
equals(THBaseService.exists_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
equals(THBaseService.exists_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
equals(THBaseService.existsAll_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
equals(THBaseService.existsAll_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
equals(THBaseService.get_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
equals(THBaseService.get_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
equals(THBaseService.getAllRegionLocations_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
equals(THBaseService.getAllRegionLocations_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
equals(THBaseService.getMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
equals(THBaseService.getMultiple_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
equals(THBaseService.getRegionLocation_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
equals(THBaseService.getRegionLocation_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
equals(THBaseService.getScannerResults_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
equals(THBaseService.getScannerResults_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
equals(THBaseService.getScannerRows_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
equals(THBaseService.getScannerRows_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
equals(THBaseService.increment_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
equals(THBaseService.increment_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
equals(THBaseService.mutateRow_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
equals(THBaseService.mutateRow_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
equals(THBaseService.openScanner_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
equals(THBaseService.openScanner_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
equals(THBaseService.put_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
equals(THBaseService.put_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
equals(THBaseService.putMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
equals(THBaseService.putMultiple_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
equals(THRegionInfo) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
equals(THRegionLocation) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
equals(Object) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
equals(TIllegalArgument) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
equals(TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
equals(Object) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
equals(TIOError) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
equals(TMutation) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
equals(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
equals(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
equals(TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
equals(TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
equals(TServerName) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
equals(TTimeRange) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.Bytes
 
equals(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
equals(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
equals(byte[], ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
equals(List<byte[]>, List<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.HashedBytes
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.ImmutableByteArray
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.NonceKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.Pair
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.Triple
 
equals(Object) - Method in class org.apache.hadoop.hbase.wal.WALKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.wal.WALSplitter.MutationReplay
 
equals(Object) - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
 
equals(Object) - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.DeleteNodeFailSilent
 
equals(Object) - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
 
equals(Object) - Method in class org.apache.hadoop.metrics2.util.MetricQuantile
 
equalsFamily(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
 
equalsIgnoreMvccVersion(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
special case for KeyValue.equals
equalsQualifier(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
 
equalsRow(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
 
equalsTimestamp(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
 
equalsType(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
 
error - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
 
error - Variable in class org.apache.hadoop.metrics2.util.MetricQuantile
 
errorCode - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
errorHandler - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
errorRate - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
Target error rate for configuring the filter and for information
errorText() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
errorText() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
errorText() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
EscapeSequences - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
Utility class for escape sequences.
estimateBase(Class, boolean) - Static method in class org.apache.hadoop.hbase.util.ClassSize
Estimate the static space taken up by the fields of a class.
ESTIMATED_HEAP_TAX - Static variable in class org.apache.hadoop.hbase.util.Bytes
Estimate of size cost to pay beyond payload in jvm for instance of byte [].
estimatedHeapSizeOf(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
This is an estimate of the heap space occupied by a cell.
estimatedHeapSizeOfWithoutTags(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
estimatedSerializedSizeOf(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
estimatedSerializedSizeOf() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
estimatedSerializedSizeOf() - Method in class org.apache.hadoop.hbase.wal.WALKey
 
estimatedSerializedSizeOfKey(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Calculates the serialized key size.
estimatedSizeOf(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
please use estimatedSerializedSizeOf(Cell)
evaluate() - Method in interface org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait.Predicate
 
evaluate(Cell) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityExpEvaluator
Evaluates whether the passed cell passes Scan/Get Authorization.
evaluateChallenge(byte[]) - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
EVENT_LOOP_CONFIG - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
 
EventHandler - Class in org.apache.hadoop.hbase.executor
Abstract base class for all HBase event handlers.
EventHandler(Server, EventType) - Constructor for class org.apache.hadoop.hbase.executor.EventHandler
Default base class constructor.
EventHandler.EventHandlerListener - Interface in org.apache.hadoop.hbase.executor
This interface provides pre- and post-process hooks for events.
eventType - Variable in class org.apache.hadoop.hbase.executor.EventHandler
 
EventType - Enum in org.apache.hadoop.hbase.executor
List of all HBase event handler types.
evict() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
EVICT_BLOCKS_ON_CLOSE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to evict all blocks of a given file from the block cache when the file is closed.
evictBlock(BlockCacheKey) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Evict block from cache.
evictBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
evictBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
evictBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
evictBlock(LruCachedBlock, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Evict the block, and it will be cached by the victim handler if exists && block may be read again later
evictBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
evictBlocksByHfileName(String) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Evicts all blocks for the given HFile.
evictBlocksByHfileName(String) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
Evicts all blocks for a specific HFile.
evictBlocksByHfileName(String) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
evictBlocksByHfileName(String) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Evicts all blocks for a specific HFile.
evictBlocksByHfileName(String) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
This method does nothing so that memcached can handle all evictions.
evicted(long, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
evictedPerEviction() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
ExampleMasterObserverWithMetrics - Class in org.apache.hadoop.hbase.coprocessor.example
An example coprocessor that collects some metrics to demonstrate the usage of exporting custom metrics from the coprocessor.
ExampleMasterObserverWithMetrics() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
 
ExampleProtos - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
ExampleProtos.CountRequest - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf type hbase.pb.CountRequest
ExampleProtos.CountRequest.Builder - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf type hbase.pb.CountRequest
ExampleProtos.CountRequestOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
ExampleProtos.CountResponse - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf type hbase.pb.CountResponse
ExampleProtos.CountResponse.Builder - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf type hbase.pb.CountResponse
ExampleProtos.CountResponseOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
ExampleProtos.RowCountService - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf service hbase.pb.RowCountService
ExampleProtos.RowCountService() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
 
ExampleProtos.RowCountService.BlockingInterface - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
ExampleProtos.RowCountService.Interface - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
ExampleProtos.RowCountService.Stub - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
ExampleRegionObserverWithMetrics - Class in org.apache.hadoop.hbase.coprocessor.example
An example coprocessor that collects some metrics to demonstrate the usage of exporting custom metrics from the coprocessor.
ExampleRegionObserverWithMetrics() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics
 
exception(Throwable) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
 
exception() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
exception() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exception(Throwable) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
Increment the count for a specific exception type.
EXCEPTION_END - Static variable in class org.apache.hadoop.hbase.CompatibilityFactory
 
EXCEPTION_START - Static variable in class org.apache.hadoop.hbase.CompatibilityFactory
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
exceptions - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
EXCEPTIONS_BUSY_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_CALL_QUEUE_TOO_BIG - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_CALL_QUEUE_TOO_BIG_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_MOVED_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_MULTI_TOO_LARGE_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_MULTI_TOO_LARGE_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_NSRE_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_OOO_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_SANITY_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_SCANNER_RESET_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_TYPE_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_UNKNOWN_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
exceptionsBusy - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsCallQueueTooBig - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsMoved - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsMultiTooLarge - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsNSRE - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsOOO - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsSanity - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsScannerReset - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsUnknown - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
ExceptionTrackingSource - Interface in org.apache.hadoop.hbase.metrics
Common interface for metrics source implementations which need to track individual exception types thrown or received.
ExceptionTrackingSourceImpl - Class in org.apache.hadoop.hbase.metrics
Common base implementation for metrics sources which need to track exceptions thrown or received.
ExceptionTrackingSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
ExceptionUtil - Class in org.apache.hadoop.hbase.util
This class handles the different interruption classes.
EXCLUDE_FROM_MINOR_COMPACTION_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Minor compaction flag in FileInfo
excludeFromMinorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
ExcludePrivateAnnotationsStandardDoclet - Class in org.apache.hadoop.hbase.classification.tools
A Doclet for excluding elements that are annotated with InterfaceAudience.Private or InterfaceAudience.LimitedPrivate.
ExcludePrivateAnnotationsStandardDoclet() - Constructor for class org.apache.hadoop.hbase.classification.tools.ExcludePrivateAnnotationsStandardDoclet
 
exec(String, ZooKeeperProtos.SplitLogTask.RecoveryMode, CancelableProgressable) - Method in interface org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor
 
exec(ExecutorService, String[]) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
EXEC_PERMISSION_CHECKS_KEY - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Configuration option that toggles whether EXEC permission checking is performed during coprocessor endpoint invocations.
execMasterService(RpcController, ClientProtos.CoprocessorServiceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
execProcedure(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Execute a distributed procedure on a cluster.
execProcedure(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Execute a distributed procedure on a cluster.
execProcedure(RpcController, MasterProtos.ExecProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Triggers an asynchronous attempt to run a distributed procedure.
execProcedure(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
execProcedure(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
 
execProcedure(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManager
Execute a distributed procedure on cluster
execProcedureWithRet(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Execute a distributed procedure on a cluster.
execProcedureWithRet(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Execute a distributed procedure on a cluster synchronously with return data
execProcedureWithRet(RpcController, MasterProtos.ExecProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Triggers a synchronous attempt to run a distributed procedure and sets return data in response.
execProcedureWithRet(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManager
Execute a distributed procedure on cluster with return data.
execRegionServerService(RpcController, ClientProtos.ClientService.BlockingInterface, ClientProtos.CoprocessorServiceCall) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Make a region server endpoint call
execRegionServerService(RpcController, ClientProtos.CoprocessorServiceRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
execRegionServerService(RpcController, ClientProtos.CoprocessorServiceRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
execService(RpcController, ClientProtos.ClientService.BlockingInterface, ClientProtos.CoprocessorServiceCall, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
execService(RpcController, MasterProtos.MasterService.BlockingInterface, ClientProtos.CoprocessorServiceCall) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
execService(RpcController, ClientProtos.CoprocessorServiceCall) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
execService(RpcController, ClientProtos.CoprocessorServiceCall) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Executes a single protocol buffer coprocessor endpoint Service method using the registered protocol handlers.
execService(RpcController, ClientProtos.CoprocessorServiceRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
execute(HConnectable<T>) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
Internal method, do not use thru HConnectionManager.
execute(Record) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter
 
execute(Admin) - Method in class org.apache.hadoop.hbase.master.normalizer.EmptyNormalizationPlan
No-op for empty plan.
execute(Admin) - Method in class org.apache.hadoop.hbase.master.normalizer.MergeNormalizationPlan
Executes normalization plan on cluster (does actual splitting/merging work).
execute(Admin) - Method in interface org.apache.hadoop.hbase.master.normalizer.NormalizationPlan
Executes normalization plan on cluster (does actual splitting/merging work).
execute(Admin) - Method in class org.apache.hadoop.hbase.master.normalizer.SplitNormalizationPlan
Executes normalization plan on cluster (does actual splitting/merging work).
execute(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
The main code of the procedure.
execute(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureInMemoryChore
 
execute(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
 
execute(StripeCompactor, ThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
 
execute(StripeCompactor, ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
Executes the request against compactor (essentially, just calls correct overload of compact method), to simulate more dynamic dispatch.
execute(Server, RegionServerServices) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
Deprecated.
use #execute(Server, RegionServerServices, User)
execute(Server, RegionServerServices, User) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
Run the transaction.
execute(Server, RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
Run the transaction.
execute(Server, RegionServerServices, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
 
execute(Server, RegionServerServices) - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
Deprecated.
use #execute(Server, RegionServerServices, User)
execute(Server, RegionServerServices, User) - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
Run the transaction.
execute(Server, RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
 
execute(Server, RegionServerServices, User) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
Run the transaction.
execute(Cluster, HttpMethod, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Execute a transaction method.
executeFromState(MasterProcedureEnv, MasterProcedureProtos.AddColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
executeFromState(MasterProcedureEnv, MasterProcedureProtos.CreateNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
executeFromState(MasterProcedureEnv, MasterProcedureProtos.CreateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
executeFromState(MasterProcedureEnv, MasterProcedureProtos.DeleteColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
executeFromState(MasterProcedureEnv, MasterProcedureProtos.DeleteNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
executeFromState(MasterProcedureEnv, MasterProcedureProtos.DeleteTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
executeFromState(MasterProcedureEnv, MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
executeFromState(MasterProcedureEnv, MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
executeFromState(MasterProcedureEnv, MasterProcedureProtos.ModifyColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
executeFromState(MasterProcedureEnv, MasterProcedureProtos.ModifyNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
executeFromState(MasterProcedureEnv, MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
executeFromState(MasterProcedureEnv, MasterProcedureProtos.ServerCrashState) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
executeFromState(MasterProcedureEnv, MasterProcedureProtos.TruncateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
executeFromState(TEnvironment, TState) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
called to perform a single step of the specified 'state' of the procedure
executePathOnly(Cluster, HttpMethod, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Execute a transaction method given only the path.
executeURI(HttpMethod, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Execute a transaction method given a complete URI.
executionTime() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
executionTimeoutTimer - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
 
executor - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
executor - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
executor - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
 
EXECUTOR_ABORT_ON_CORRUPTION - Static variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureConstants
Procedure replay sanity check.
ExecutorService - Class in org.apache.hadoop.hbase.executor
This is a generic executor service.
ExecutorService(String) - Constructor for class org.apache.hadoop.hbase.executor.ExecutorService
Default constructor.
ExecutorService.ExecutorStatus - Class in org.apache.hadoop.hbase.executor
A snapshot of the status of a particular executor.
ExecutorService.RunningEventStatus - Class in org.apache.hadoop.hbase.executor
The status of a particular event that is in the middle of being handled by an executor.
ExecutorService.RunningEventStatus(Thread, EventHandler) - Constructor for class org.apache.hadoop.hbase.executor.ExecutorService.RunningEventStatus
 
ExecutorType - Enum in org.apache.hadoop.hbase.executor
The following is a list of all executor types, both those that run in the master and those that run in the regionserver.
exist - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
existingSource - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
 
existingWriters - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
exists(Get) - Method in class org.apache.hadoop.hbase.client.HTable
Test for the existence of columns in the table, as specified by the Get.
exists(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
exists(List<Get>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
exists(Get) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
exists(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
Deprecated.
exists(Get) - Method in interface org.apache.hadoop.hbase.client.Table
Test for the existence of columns in the table, as specified by the Get.
exists(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
 
exists(Get) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
exists(List<Get>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
Deprecated.
exists(ByteBuffer, TGet, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
exists(ByteBuffer, TGet, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
exists(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
exists(ByteBuffer, TGet) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Test for the existence of columns in the table, as specified in the TGet.
exists(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
exists(String, Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
exists is an idempotent operation.
exists(String, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
exists is an idempotent operation.
existsAll(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
Test for the existence of columns in the table, as specified by the Gets.
existsAll(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
existsAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
Test for the existence of columns in the table, as specified by the Gets.
existsAll(List<Get>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
exists(List) is really a list of get() calls.
existsAll(ByteBuffer, List<TGet>, AsyncMethodCallback<THBaseService.AsyncClient.existsAll_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
existsAll(ByteBuffer, List<TGet>, AsyncMethodCallback<THBaseService.AsyncClient.existsAll_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
existsAll(ByteBuffer, List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
existsAll(ByteBuffer, List<TGet>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Test for the existence of columns in the table, as specified by the TGets.
existsAll(ByteBuffer, List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
ExistsResource - Class in org.apache.hadoop.hbase.rest
 
ExistsResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.ExistsResource
Constructor
EXIT_FAILURE - Static variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
EXIT_SUCCESS - Static variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
exitIfOOME(Throwable) - Static method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
expand(ExpressionNode) - Method in class org.apache.hadoop.hbase.security.visibility.ExpressionExpander
 
expectAtLeastMajorVersion(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
EXPECTED_NUBS_PLUS_LEAVES - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
 
expectMajorVersion(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
expectMinorVersion(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
expectPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
expectSpecific() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
Throws an exception if the block category passed is the special category meaning "all categories".
EXPIRATION_TIME_KEY - Static variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
expirationDate - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
expireNow() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
expireServer(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
explicitColumnQuery - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
ExplicitColumnTracker - Class in org.apache.hadoop.hbase.regionserver.querymatcher
This class is used for the tracking and enforcement of columns and numbers of versions during the course of a Get or Scan operation, when explicit column qualifiers have been asked for in the query.
ExplicitColumnTracker(NavigableSet<byte[]>, int, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
Default constructor.
ExploringCompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
Class to pick which files if any to compact together.
ExploringCompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.ExploringCompactionPolicy
Constructor for ExploringCompactionPolicy.
ExponentialClientBackoffPolicy - Class in org.apache.hadoop.hbase.client.backoff
Simple exponential backoff policy on for the client that uses a percent^4 times the max backoff to generate the backoff time.
ExponentialClientBackoffPolicy(Configuration) - Constructor for class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
ExponentialCompactionWindowFactory - Class in org.apache.hadoop.hbase.regionserver.compactions
Exponential compaction window implementation.
ExponentialCompactionWindowFactory(CompactionConfiguration) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory
 
Export - Class in org.apache.hadoop.hbase.mapreduce
Export an HBase table.
Export() - Constructor for class org.apache.hadoop.hbase.mapreduce.Export
 
ExportSnapshot - Class in org.apache.hadoop.hbase.snapshot
Export the specified snapshot to a given FileSystem.
ExportSnapshot() - Constructor for class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
ExportSnapshot.Counter - Enum in org.apache.hadoop.hbase.snapshot
 
ExportSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when a snapshot could not be exported due to an error during the operation.
ExportSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.ExportSnapshotException
 
ExportSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.ExportSnapshotException
 
expression - Variable in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
ExpressionExpander - Class in org.apache.hadoop.hbase.security.visibility
 
ExpressionExpander() - Constructor for class org.apache.hadoop.hbase.security.visibility.ExpressionExpander
 
ExpressionNode - Interface in org.apache.hadoop.hbase.security.visibility.expression
 
ExpressionParser - Class in org.apache.hadoop.hbase.security.visibility
 
ExpressionParser() - Constructor for class org.apache.hadoop.hbase.security.visibility.ExpressionParser
 
extendedForName(String) - Static method in class org.apache.hadoop.hbase.util.Classes
Equivalent of Class.forName(String) which also returns classes for primitives like boolean, etc.
extendLimit(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
 
extractAndPartitionTags(Cell, List<Tag>, List<Tag>) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
Extracts and partitions the visibility tags and nonVisibility Tags
extractArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.CompareFilter
 
extractFileNumFromWAL(WAL) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
It returns the file create timestamp from the file name.
extractFilterSimpleExpression(byte[], int) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Extracts a simple filter expression from the filter string given by the user
extractKeyValues(Result) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Extract columns values from the current record.
extractKeyValues(Result) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Extract columns values from the current record.
extractLabelsAndAuths(List<List<Cell>>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
extractScanFromConf(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
 
extractVisibilityTags(Cell, List<Tag>) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
Extract the visibility tags of the given Cell into the given List
extraHeapSize() - Method in class org.apache.hadoop.hbase.client.Increment
 
extraHeapSize() - Method in class org.apache.hadoop.hbase.client.Mutation
Subclasses should override this method to add the heap size of their own fields.

F

failed() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
failed() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
failed() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
FAILED_APPEND_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
FAILED_DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
FAILED_GET_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
FAILED_INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
FAILED_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
FAILED_SCAN_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
FAILED_SERVER_EXPIRY_DEFAULT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
FAILED_SERVER_EXPIRY_KEY - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
FailedArchiveException - Exception in org.apache.hadoop.hbase.backup
Exception indicating that some files in the requested set could not be archived.
FailedArchiveException(String, Collection<Path>) - Constructor for exception org.apache.hadoop.hbase.backup.FailedArchiveException
 
failedBulkLoad(byte[], String) - Method in interface org.apache.hadoop.hbase.regionserver.Region.BulkLoadListener
Called after a failed HFile load
FailedLogCloseException - Exception in org.apache.hadoop.hbase.regionserver.wal
Thrown when we fail close of the write-ahead-log file.
FailedLogCloseException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedLogCloseException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedLogCloseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
FailedLogCloseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
 
failedOnException() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
Returns whether or not a server exception was generated in the prior RPC invocation.
FailedSanityCheckException - Exception in org.apache.hadoop.hbase.exceptions
Exception thrown if a mutation fails sanity checks.
FailedSanityCheckException() - Constructor for exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
default constructor
FailedSanityCheckException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
 
FailedSanityCheckException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
 
failedSanityException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
failedSanityException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
FailedServerException - Exception in org.apache.hadoop.hbase.ipc
Indicates that we're trying to connect to a already known as dead server.
FailedServerException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.FailedServerException
 
failedServerName - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
 
failedServers - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
FailedServers - Class in org.apache.hadoop.hbase.ipc
A class to manage a list of servers that failed recently.
FailedServers(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.FailedServers
 
FailedSyncBeforeLogCloseException - Exception in org.apache.hadoop.hbase.regionserver.wal
Thrown when we fail close of the write-ahead-log file.
FailedSyncBeforeLogCloseException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
FailedSyncBeforeLogCloseException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
FailedSyncBeforeLogCloseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
FailedSyncBeforeLogCloseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
 
failInsert() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
failoverCleanupDone - Variable in class org.apache.hadoop.hbase.master.AssignmentManager
Indicator that AssignmentManager has recovered the region states so that ServerShutdownHandler can be fully enabled and re-assign regions of dead servers.
FAILURE - Static variable in class org.apache.hadoop.hbase.regionserver.OperationStatus
Singleton for failed operations.
failureSleep - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
FALLBACK_TO_INSECURE_CLIENT_AUTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
Whether we allow a fallback to SIMPLE auth for insecure clients when security is enabled.
fallbackAllowed - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
fallbackAllowed - Variable in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
FallbackDisallowedException - Exception in org.apache.hadoop.hbase.ipc
Indicate that the rpc server tells client to fallback to simple auth but client is disabled to do so.
FallbackDisallowedException() - Constructor for exception org.apache.hadoop.hbase.ipc.FallbackDisallowedException
 
fallbackToFsChecksum(int) - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
Read from non-checksum stream failed, fall back to FS checksum.
family - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
column name
family - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
family - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
family - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
family - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
column family to check
family - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
column family to check
family - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
column family to check
FAMILY_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
Size of the family length field in bytes
FAMILY_VALUE - Static variable in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
FAMILY = 1;
familyBuffer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
familyDeduplicator - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
familyDict - Variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
 
FamilyFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on the column family.
FamilyFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.FamilyFilter
Constructor.
familyLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
familyMap - Variable in class org.apache.hadoop.hbase.client.Mutation
 
familyOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
familyOffsetsOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
familyOffsetWidth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
familyRange - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
familyReader - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
familySet() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the keys in the familyMap
familyStamp - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
familyTokenizer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
familyVersionStamps - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
familyWriter - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
fanIndex - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
fanOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
fanOut - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
fanOut - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
FastDiffDeltaEncoder - Class in org.apache.hadoop.hbase.io.encoding
Encoder similar to DiffKeyDeltaEncoder but supposedly faster.
FastDiffDeltaEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
 
FastDiffDeltaEncoder.FastDiffSeekerState - Class in org.apache.hadoop.hbase.io.encoding
 
FastDiffDeltaEncoder.FastDiffSeekerState() - Constructor for class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffSeekerState
 
FastLongHistogram - Class in org.apache.hadoop.hbase.metrics.impl
FastLongHistogram is a thread-safe class that estimate distribution of data and computes the quantiles.
FastLongHistogram() - Constructor for class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
Constructor.
FastLongHistogram(int) - Constructor for class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
Constructor.
FastLongHistogram(int, long, long) - Constructor for class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
Constructor setting the bins assuming a uniform distribution within a range.
FastLongHistogram - Class in org.apache.hadoop.hbase.util
Deprecated.
FastLongHistogram() - Constructor for class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
Constructor.
FastLongHistogram(int) - Constructor for class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
Constructor.
FastLongHistogram(int, long, long) - Constructor for class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
Constructor setting the bins assuming a uniform distribution within a range.
FastPathBalancedQueueRpcExecutor - Class in org.apache.hadoop.hbase.ipc
Balanced queue executor with a fastpath.
FastPathBalancedQueueRpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutor
 
FastPathBalancedQueueRpcExecutor(String, int, String, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutor
 
FatalConnectionException - Exception in org.apache.hadoop.hbase.ipc
Thrown when server finds fatal issue w/ connection setup: e.g.
FatalConnectionException() - Constructor for exception org.apache.hadoop.hbase.ipc.FatalConnectionException
 
FatalConnectionException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.FatalConnectionException
 
FatalConnectionException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.FatalConnectionException
 
FAVORED_NODES_NUM - Static variable in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
 
FavoredNodeAssignmentHelper - Class in org.apache.hadoop.hbase.master.balancer
Helper class for FavoredNodeLoadBalancer that has all the intelligence for racks, meta scans, etc.
FavoredNodeAssignmentHelper(List<ServerName>, Configuration) - Constructor for class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
 
FavoredNodeAssignmentHelper(List<ServerName>, RackManager) - Constructor for class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
 
FavoredNodeLoadBalancer - Class in org.apache.hadoop.hbase.master.balancer
An implementation of the LoadBalancer that assigns favored nodes for each region.
FavoredNodeLoadBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
 
favoredNodes - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
FAVOREDNODES_QUALIFIER - Static variable in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
 
FavoredNodesForRegion - Interface in org.apache.hadoop.hbase.regionserver
Abstraction that allows different modules in RegionServer to update/get the favored nodes information for regions.
FavoredNodesPlan - Class in org.apache.hadoop.hbase.master.balancer
This class contains the mapping information between each region and its favored region server list.
FavoredNodesPlan() - Constructor for class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
 
FavoredNodesPlan.Position - Enum in org.apache.hadoop.hbase.master.balancer
 
FeedUserAuthScanLabelGenerator - Class in org.apache.hadoop.hbase.security.visibility
If the passed in authorization is null, then this ScanLabelGenerator feeds the set of predefined authorization labels for the given user.
FeedUserAuthScanLabelGenerator() - Constructor for class org.apache.hadoop.hbase.security.visibility.FeedUserAuthScanLabelGenerator
 
fetchGlobalQuotas(String, Connection, List<Get>, QuotaUtil.KeyFromRow<K>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
fetchNamespaceQuotas(Connection, List<Get>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
fetchSlavesAddresses(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
Get the list of all the region servers from the specified peer
fetchTableQuotas(Connection, List<Get>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
fetchUserQuotas(Connection, List<Get>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
FEWEST_ITEMS_IN_BUCKET - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
So, what is the minimum amount of items we'll tolerate in a single bucket?
Field - Enum in org.apache.hadoop.hbase.hbtop.field
Represents fields that are displayed in the top screen.
fieldForId(int) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
fieldForId(int) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
fieldForId(int) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
fieldForId(int) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
fieldForId(int) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
FieldInfo - Class in org.apache.hadoop.hbase.hbtop.field
Information about a field.
FieldInfo(Field, int, boolean) - Constructor for class org.apache.hadoop.hbase.hbtop.field.FieldInfo
 
fields - Variable in class org.apache.hadoop.hbase.types.Struct
 
fields - Variable in class org.apache.hadoop.hbase.types.StructBuilder
 
FieldScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.field
The presentation logic for the field screen.
FieldScreenPresenter(FieldScreenView, Field, List<Field>, EnumMap<Field, Boolean>, FieldScreenPresenter.ResultListener, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
 
FieldScreenPresenter.ResultListener - Interface in org.apache.hadoop.hbase.hbtop.screen.field
 
FieldScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.field
The screen where we can change the displayed fields, the sort key and the order of the fields.
FieldScreenView(Screen, Terminal, Field, List<Field>, EnumMap<Field, Boolean>, FieldScreenPresenter.ResultListener, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
 
FieldValue - Class in org.apache.hadoop.hbase.hbtop.field
Represents a value of a field.
FieldValueType - Enum in org.apache.hadoop.hbase.hbtop.field
Represents the type of a FieldValue.
FIFOCompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
FIFO compaction policy selects only files which have all cells expired.
FIFOCompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.FIFOCompactionPolicy
 
FifoRpcScheduler - Class in org.apache.hadoop.hbase.ipc
A very simple RpcScheduler} that serves incoming requests in order.
FifoRpcScheduler(Configuration, int) - Constructor for class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
FifoRpcSchedulerFactory - Class in org.apache.hadoop.hbase.regionserver
Factory to use when you want to use the FifoRpcScheduler
FifoRpcSchedulerFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.FifoRpcSchedulerFactory
 
FILE_DELIMITER - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
 
FILE_SYSTEM_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
Current version of file system.
FileCleanerDelegate - Interface in org.apache.hadoop.hbase.master.cleaner
General interface for cleaning files from a folder (generally an archive or backup folder).
fileInfo - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
fileInfo - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
A "file info" block: a key-value map of file-wide metadata.
FileIOEngine - Class in org.apache.hadoop.hbase.io.hfile.bucket
IO engine that stores data to a file on the local file system.
FileIOEngine(long, String...) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
 
fileLength - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
FileLink - Class in org.apache.hadoop.hbase.io
The FileLink is a sort of hardlink, that allows access to a file given a set of locations.
FileLink() - Constructor for class org.apache.hadoop.hbase.io.FileLink
 
FileLink(Path, Path...) - Constructor for class org.apache.hadoop.hbase.io.FileLink
 
FileLink(Collection<Path>) - Constructor for class org.apache.hadoop.hbase.io.FileLink
 
fileSize - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Size of this file.
FileStatusFilter - Interface in org.apache.hadoop.hbase.util
 
fileSystemManager - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
 
FileSystemVersionException - Exception in org.apache.hadoop.hbase.util
Thrown when the file system needs to be upgraded
FileSystemVersionException() - Constructor for exception org.apache.hadoop.hbase.util.FileSystemVersionException
default constructor
FileSystemVersionException(String) - Constructor for exception org.apache.hadoop.hbase.util.FileSystemVersionException
 
FILL_HEADER - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
fillFamilyRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.CellUtil
 
fillInBytes(byte[]) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
fillQualifierRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.CellUtil
 
fillRegion(HRegion) - Method in interface org.apache.hadoop.hbase.util.ModifyRegionUtils.RegionFillTask
 
fillRowRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.CellUtil
ByteRange
fillTagRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.CellUtil
 
fillUp(TableName, SnapshotOfRegionAssignmentFromMeta, Map<String, Map<String, Float>>) - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
 
fillUpDispersion(TableName, SnapshotOfRegionAssignmentFromMeta, FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
Use this to project the dispersion scores
fillValueRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.CellUtil
 
filter - Variable in class org.apache.hadoop.hbase.client.Query
 
Filter - Class in org.apache.hadoop.hbase.filter
Interface for row and column filters directly applied within the regionserver.
Filter() - Constructor for class org.apache.hadoop.hbase.filter.Filter
 
filter(Mapper<WALKey, WALEdit, ImmutableBytesWritable, Mutation>.Context, Cell) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
 
filter - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
filter(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
 
filter(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.ClusterMarkingEntryFilter
 
filter(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.ScopeWALEntryFilter
 
filter(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.SystemTableWALEntryFilter
 
filter(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.TableCfWALEntryFilter
 
filter(WAL.Entry) - Method in interface org.apache.hadoop.hbase.replication.WALEntryFilter
Applies the filter, possibly returning a different Entry instance.
filter - Variable in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
filter - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
filter - Variable in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
Filter.ReturnCode - Enum in org.apache.hadoop.hbase.filter
Return codes for filterValue().
FILTER_ARGS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
FILTER_CLASS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
FILTER_CLASSES - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
FILTER_PACKAGE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
Package containing filters
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.Filter
If this returns true, the scan will terminate.
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterBase
Filters that never filter all remaining can inherit this implementation that never stops the filter early.
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
FilterBase - Class in org.apache.hadoop.hbase.filter
Abstract base class to help you implement new Filters.
FilterBase() - Constructor for class org.apache.hadoop.hbase.filter.FilterBase
 
filterBulk(ArrayList<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
 
filterByLeafAndReverse(ArrayList<TokenizerNode>, boolean) - Static method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
static
filterCell(Cell, Predicate<byte[]>) - Method in class org.apache.hadoop.hbase.replication.BulkLoadCellFilter
Filters the bulk load cell using the supplied predicate.
filterCell(WAL.Entry, Cell) - Method in class org.apache.hadoop.hbase.replication.ScopeWALEntryFilter
 
filterCell(WAL.Entry, Cell) - Method in class org.apache.hadoop.hbase.replication.TableCfWALEntryFilter
 
filterCell(WAL.Entry, Cell) - Method in interface org.apache.hadoop.hbase.replication.WALCellFilter
Applies the filter, possibly returning a different Cell instance.
filterColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
filterColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
FilterContainer - Interface in org.apache.hadoop.hbase.http
A container interface to add javax.servlet.Filter.
FilterDisplayModeScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.top
The presentation logic for the filter display mode.
FilterDisplayModeScreenPresenter(FilterDisplayModeScreenView, List<RecordFilter>, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenPresenter
 
FilterDisplayModeScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.top
The filter display mode in the top screen.
FilterDisplayModeScreenView(Screen, Terminal, int, List<RecordFilter>, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenView
 
filterFileStatuses(FileStatus[], FileStatusFilter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Filters FileStatuses in an array and returns a list
filterFileStatuses(Iterator<FileStatus>, FileStatusFilter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Filters FileStatuses in an iterator and returns a list
filterIfMissing - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
FilterInitializer - Class in org.apache.hadoop.hbase.http
Initialize a javax.servlet.Filter.
FilterInitializer() - Constructor for class org.apache.hadoop.hbase.http.FilterInitializer
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
A way to filter based on the column family, column qualifier and/or the column value.
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
filterKeyValue(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filterKv(Filter, Cell) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Attempt to filter out the keyvalue
FilterList - Class in org.apache.hadoop.hbase.filter
Implementation of Filter that represents an ordered List of Filters which will be evaluated with a specified boolean operator FilterList.Operator.MUST_PASS_ALL (AND) or FilterList.Operator.MUST_PASS_ONE (OR).
FilterList(FilterList.Operator, List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a set of Filters and an operator.
FilterList(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a set of Filters.
FilterList(Filter...) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a var arg number of Filters.
FilterList(FilterList.Operator) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes an operator.
FilterList(FilterList.Operator, Filter...) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a var arg number of Filters and an operator.
FilterList.Operator - Enum in org.apache.hadoop.hbase.filter
set operator
FilterListBase - Class in org.apache.hadoop.hbase.filter
Base class for FilterList.
FilterListBase(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterListBase
 
FilterListWithAND - Class in org.apache.hadoop.hbase.filter
FilterListWithAND represents an ordered list of filters which will be evaluated with an AND operator.
FilterListWithAND(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterListWithAND
 
FilterListWithOR - Class in org.apache.hadoop.hbase.filter
FilterListWithOR represents an ordered list of filters which will be evaluated with an OR operator.
FilterListWithOR(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterListWithOR
 
filterNames - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
filterOutRow - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.Filter
Last chance to veto row based on previous Filter.filterKeyValue(Cell) calls.
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterBase
Filters that never filter by rows based on previously gathered state from Filter.filterKeyValue(Cell) can inherit this implementation that never filters a row.
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterRow - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.Filter
Chance to alter the list of Cells to be submitted.
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.FilterBase
Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.FilterList
Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
filterRowCellsWithRet(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.Filter
Filters a row based on the row key.
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterBase
Filters that do not filter by row key can inherit this implementation that never filters anything.
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
filters - Variable in class org.apache.hadoop.hbase.filter.FilterListBase
 
filterString - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
 
filterString - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
filterString - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
FilterWrapper - Class in org.apache.hadoop.hbase.filter
This is a Filter wrapper class which is used in the server side.
FilterWrapper(Filter) - Constructor for class org.apache.hadoop.hbase.filter.FilterWrapper
 
FilterWrapper.FilterRowRetCode - Enum in org.apache.hadoop.hbase.filter
 
finalCheckForErrors() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
finalize(ProcedureWALFormat.Loader) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
 
findBigRanges(Collection<R>, int) - Static method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
Find specified number of top ranges in a big overlap group.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TAppend._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TAppend._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TAuthorization._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TCellVisibility._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionLocation._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TServerName._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
Find the _Fields constant that matches name, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TAppend._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TAppend._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TAuthorization._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TCellVisibility._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionLocation._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TServerName._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TAppend._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TAppend._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TAuthorization._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TCellVisibility._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionLocation._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TServerName._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByValue(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TCompareOp
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDeleteType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDurability
Find a the enum type by its integer value, as defined in the Thrift IDL.
findCommonPrefix(ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Find length of common prefix of two parts in the buffer
findCommonPrefix(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Find length of common prefix in two arrays.
findCommonPrefixInFamilyPart(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.CellComparator
 
findCommonPrefixInFlatKey(Cell, Cell, boolean, boolean) - Static method in class org.apache.hadoop.hbase.CellUtil
Find length of common prefix in keys of the cells, considering key as byte[] if serialized in KeyValue.
findCommonPrefixInQualifierPart(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.CellComparator
 
findCommonPrefixInRowPart(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.CellComparator
 
findConstructor(Class<T>, Object...) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
 
findCoprocessor(String) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Find a coprocessor implementation by class name
findCoprocessorEnvironment(String) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Find a coprocessor environment by class name
findCoprocessors(Class<T>) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Find list of coprocessors that extend/implement the given class/interface
findEntry(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
Finds the index of an entry.
findEntry(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
 
findException(Object) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Look for an exception we know in the remote exception: - hadoop.ipc wrapped exceptions - nested exceptions Looks for: RegionMovedException / RegionOpeningException / RegionTooBusyException / ThrottlingException
findPort - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
finish(ServerName, String) - Method in interface org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher
finish the partially done task.
finish() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
 
finish(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
Complete processing for this dead server.
finish(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
 
finish(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
finish(String) - Method in interface org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
Finish the controller.
finish() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
 
finishBlockAndWriteHeaderAndData(DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
Writes the header and the compressed data of this block (or uncompressed data when not using compression) into the given stream.
finishClose(FixedFileTrailer) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Sets remaining trailer fields, writes the trailer to disk, and optionally closes the output stream.
finishClose(FixedFileTrailer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
 
finishFileInfo() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Add last bits of metadata to file info before it is written out.
finishFileInfo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
 
finishInit(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Additional initialization steps
FinishRegionRecoveringHandler - Class in org.apache.hadoop.hbase.regionserver.handler
 
FinishRegionRecoveringHandler(RegionServerServices, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.FinishRegionRecoveringHandler
 
finishSplitLogFile(String, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
Completes the work done by splitLogFile by archiving logs
finishWriting(boolean) - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
Wait for writer threads to dump all info to the sink
finishWritingAndClose() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
first() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
first - Variable in class org.apache.hadoop.hbase.util.Pair
 
first() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
FIRST_META_REGIONINFO - Static variable in class org.apache.hadoop.hbase.HRegionInfo
HRegionInfo for first meta region
firstCellInBlock - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
First cell in a block.
firstEntry() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
firstInsertionIndex - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
firstKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
firstKey() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
FirstKeyOnlyFilter - Class in org.apache.hadoop.hbase.filter
A filter that will only return the first KV from each row.
FirstKeyOnlyFilter() - Constructor for class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
FirstKeyValueMatchingQualifiersFilter - Class in org.apache.hadoop.hbase.filter
The filter looks for the given columns in KeyValue.
FirstKeyValueMatchingQualifiersFilter(Set<byte[]>) - Constructor for class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Constructor which takes a set of columns.
firstRow() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
 
firstRow() - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
In HBase, the first row is represented by an empty byte array.
firstRow() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
 
FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.ScanInfo
 
FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
FIXED_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
 
FixedFileTrailer - Class in org.apache.hadoop.hbase.io.hfile
The HFile has a fixed trailer which contains offsets to other variable parts of the file.
FixedIntervalRateLimiter - Class in org.apache.hadoop.hbase.quotas
With this limiter resources will be refilled only after a fixed interval of time.
FixedIntervalRateLimiter() - Constructor for class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
 
FixedLengthWrapper<T> - Class in org.apache.hadoop.hbase.types
Wraps an existing DataType implementation as a fixed-length version of itself.
FixedLengthWrapper(DataType<T>, int) - Constructor for class org.apache.hadoop.hbase.types.FixedLengthWrapper
Create a fixed-length version of the wrapped.
fixEmptyMetaCells() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
To fix the empty REGIONINFO_QUALIFIER rows from hbase:meta
fixExpiredTableLocks() - Method in class org.apache.hadoop.hbase.util.hbck.TableLockChecker
 
fixMetaHoleOnlineAndAddReplicas(Configuration, HRegionInfo, Collection<ServerName>, int) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
Puts the specified HRegionInfo into META with replica related columns
fixMultiAssignment(HConnection, HRegionInfo, List<ServerName>) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
Fix multiple assignment by doing silent closes on each RS hosting the region and then force ZK unassigned node to OFFLINE to trigger assignment by master.
fixOrphanTables() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
To fix orphan table by creating a .tableinfo file under tableDir
1.
fixRowFanMissForward(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
 
fixRowFanMissReverse(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
complete seek when fan mismatch
fixRowTokenMissForward(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
 
fixRowTokenMissReverse(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
 
fixUnassigned(Admin, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
Fix unassigned by creating/transition the unassigned ZK node for this region to OFFLINE state with a special flag to tell the master that this is a forced operation by HBCK.
fixUnDeletedQueues() - Method in class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
 
floatValue() - Method in class org.apache.hadoop.hbase.util.LongAdder
Returns the LongAdder.sum() as a float after a widening primitive conversion.
floor(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
floorEntry(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
floorKey(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
flush(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush a table.
flush() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Executes all the buffered, asynchronous Mutation operations and waits until they are done.
flush() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
flush(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Flush a table.
flush(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
flush(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
flush() - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
 
flush() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
Expensive method.
flush(PrintWriter) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
 
flush() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
flush() - Method in interface org.apache.hadoop.hbase.io.CellOutputStream
Let the implementation decide what to do.
flush() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
 
flush() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
 
flush(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
flush(boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Flush the cache.
FLUSH - Static variable in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
flush() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
 
flush(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.SaslWrapHandler
 
flush() - Method in interface org.apache.hadoop.hbase.util.JSONBean.Writer
 
flush() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
WriterThread call this function to help flush internal remaining edits in buffer before close
FLUSH_MEMSTORE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSH_MEMSTORE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSH_OUTPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSH_OUTPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSH_POLICY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
FLUSH_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSH_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSH_REQUEST_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
 
FLUSH_REQUEST_THREADS_KEY - Static variable in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
 
FLUSH_REQUEST_WAKE_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
 
FLUSH_TABLE_PROCEDURE_SIGNATURE - Static variable in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
 
FLUSH_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSH_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSH_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
 
FLUSH_TIMEOUT_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
 
FLUSH_TO_L0_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
Whether to flush memstore to L0 files, or directly to stripes.
FlushAllStoresPolicy - Class in org.apache.hadoop.hbase.regionserver
A FlushPolicy that always flushes all stores for a given region.
FlushAllStoresPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.FlushAllStoresPolicy
 
flushBase64() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Method added by PHIL.
flushBuffer() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
flushcache(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Flush the cache.
flushCache(long, MemStoreSnapshot, MonitoredTask, ThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Write out current snapshot.
flushCommits() - Method in class org.apache.hadoop.hbase.client.HTable
Executes all the buffered Put operations.
flushCommits() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
as of 1.0.0. Replaced by BufferedMutator.flush()
flushCommits() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
flushCommits() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
flushed - Variable in class org.apache.hadoop.hbase.codec.BaseEncoder
 
FLUSHED_CELLS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSHED_CELLS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSHED_CELLS_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSHED_CELLS_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSHED_MEMSTORE_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSHED_MEMSTORE_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSHED_OUTPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSHED_OUTPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
FLUSHES_QUEUED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
FLUSHES_QUEUED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
FlushLargeStoresPolicy - Class in org.apache.hadoop.hbase.regionserver
A FlushPolicy that only flushes store larger a given threshold.
FlushLargeStoresPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
 
FlushPolicy - Class in org.apache.hadoop.hbase.regionserver
A flush policy determines the stores that need to be flushed when flushing a region.
FlushPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.FlushPolicy
 
FlushPolicyFactory - Class in org.apache.hadoop.hbase.regionserver
The class that creates a flush policy from a conf and HTableDescriptor.
FlushPolicyFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
 
flushRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Flush an individual region.
flushRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Flush an individual region.
flushRegion(RpcController, AdminProtos.FlushRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Flush a region on the region server.
FlushRegionCallable - Class in org.apache.hadoop.hbase.client
A Callable for flushRegion() RPC.
FlushRegionCallable(ClusterConnection, RpcControllerFactory, TableName, byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.client.FlushRegionCallable
 
FlushRegionCallable(ClusterConnection, RpcControllerFactory, HRegionInfo, boolean) - Constructor for class org.apache.hadoop.hbase.client.FlushRegionCallable
 
flushRegionsIfNecessary(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
If the durability is set to Durability.SKIP_WAL and the data is imported to hbase, we need to flush all the regions of the table as the data is held in memory and is also not present in the Write Ahead Log to replay in scenarios of a crash.
flushRequested(FlushType, Region) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequestListener
Callback which will get called when a flush request is made for a region.
FlushRequester - Interface in org.apache.hadoop.hbase.regionserver
Request a flush.
FlushRequestListener - Interface in org.apache.hadoop.hbase.regionserver
Listener which will get notified regarding flush requests of regions.
flushSnapshot(MemStoreSnapshot, long, MonitoredTask, ThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher
 
flushSnapshot(MemStoreSnapshot, long, MonitoredTask, ThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher
 
FlushSnapshotSubprocedure - Class in org.apache.hadoop.hbase.regionserver.snapshot
This online snapshot implementation uses the distributed procedure framework to force a store flush and then records the hfiles.
FlushSnapshotSubprocedure(ProcedureMember, ForeignExceptionDispatcher, long, long, List<Region>, HBaseProtos.SnapshotDescription, RegionServerSnapshotManager.SnapshotSubprocedurePool) - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
 
FlushSnapshotSubprocedure.RegionSnapshotTask - Class in org.apache.hadoop.hbase.regionserver.snapshot
Callable for adding files to snapshot manifest working dir.
FlushSnapshotSubprocedure.RegionSnapshotTask(Region, HBaseProtos.SnapshotDescription, boolean, ForeignExceptionDispatcher) - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure.RegionSnapshotTask
 
FlushTableSubprocedure - Class in org.apache.hadoop.hbase.procedure.flush
This flush region implementation uses the distributed procedure framework to flush table regions.
FlushTableSubprocedure(ProcedureMember, ForeignExceptionDispatcher, long, long, List<Region>, String, RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool) - Constructor for class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
 
FlushThroughputControllerFactory - Class in org.apache.hadoop.hbase.regionserver.throttle
 
followCurrentFan() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
followFan(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
followFirstFan() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
followLastFan() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
followLastFansUntilExhausted() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
 
followNextFan() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
followPreviousFan() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
forceRecompute() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Force a re-computation of the metrics.
forceSelect(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
Forces external selection to be applied for this compaction.
ForeignException - Exception in org.apache.hadoop.hbase.errorhandling
A ForeignException is an exception from another thread or process.
ForeignException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.errorhandling.ForeignException
Create a new ForeignException that can be serialized.
ForeignException(String, String) - Constructor for exception org.apache.hadoop.hbase.errorhandling.ForeignException
Create a new ForeignException that can be serialized.
ForeignExceptionDispatcher - Class in org.apache.hadoop.hbase.errorhandling
The dispatcher acts as the state holding entity for foreign error handling.
ForeignExceptionDispatcher(String) - Constructor for class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
 
ForeignExceptionDispatcher() - Constructor for class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
 
ForeignExceptionListener - Interface in org.apache.hadoop.hbase.errorhandling
The ForeignExceptionListener is an interface for objects that can receive a ForeignException.
ForeignExceptionSnare - Interface in org.apache.hadoop.hbase.errorhandling
This is an interface for a cooperative exception throwing mechanism.
ForeignExceptionUtil - Class in org.apache.hadoop.hbase.util
Helper to convert Exceptions and StackTraces from/to protobuf.
FOREVER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
FOREVER - Static variable in class org.apache.hadoop.hbase.HConstants
Unlimited time-to-live.
format() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Header
 
format - Variable in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
format - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
format - Variable in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
format(String, PrettyPrinter.Unit) - Static method in class org.apache.hadoop.hbase.util.PrettyPrinter
 
FORMAT_VERSION_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
The configuration key for HFile version to use for new files
formatLogFilters(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
formatLogFilters(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
formatLogFilters(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
formatStats(BloomFilterBase) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
A human-readable string with statistics for the given Bloom filter.
formatTestingStats() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
 
formatThreadInfo(ThreadInfo, String) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
Format the given ThreadInfo object as a String.
formatTime(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
formatZKString() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmplImpl
 
formNoTagsKeyValue() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
formNoTagsKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
foundColumn - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
frags - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
freeBlock(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
Free a block with the offset
freeBlock(long[]) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
freeCount() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
freeMemory(long) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Free the requested amount of memory from the LRU map.
fromArrays(Collection<byte[]>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
 
fromByte(byte) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
fromBytes(byte[]) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
fromBytes(byte[]) - Static method in class org.apache.hadoop.hbase.master.TableLockManager
Public for hbck
fromBytes(byte[]) - Static method in class org.apache.hadoop.hbase.util.vint.UFIntTool
 
fromBytes(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.vint.UFIntTool
 
fromCode(int) - Static method in enum org.apache.hadoop.hbase.wal.WALKey.Version
 
fromDeleteType(ClientProtos.MutationProto.DeleteType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer DeleteType to delete KeyValue type.
fromHex(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
Create a byte array from a string of hash digits.
fromList(List<Tag>) - Static method in class org.apache.hadoop.hbase.Tag
Write a list of tags into a byte array
fromNamespaceEntry(String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
 
fromNamespaceEntry(byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
 
fromParts(String, int) - Static method in class org.apache.hadoop.hbase.net.Address
 
fromProto(ErrorHandlingProtos.ForeignExceptionMessage) - Static method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
 
fromRegion - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.SwapRegionsAction
 
fromRowSpec(String, RowSpec, Filter, boolean) - Static method in class org.apache.hadoop.hbase.rest.ResultGenerator
 
fromScan(Scan) - Static method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
fromServer - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.MoveRegionAction
 
fromServer - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.SwapRegionsAction
 
fromString(String) - Method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
 
fromString(String) - Static method in class org.apache.hadoop.hbase.net.Address
 
fromThrottle(QuotaProtos.Throttle) - Static method in class org.apache.hadoop.hbase.quotas.QuotaLimiterFactory
 
fs - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
fs - Variable in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
 
fs - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
fs - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
file system instance
fs - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
FS_PREAD_TIME_HISTO_DESC - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
 
FS_PREAD_TIME_HISTO_KEY - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
 
FS_READ_TIME_HISTO_DESC - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
 
FS_READ_TIME_HISTO_KEY - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
 
FS_SHUTDOWN_HOOK_WAIT - Static variable in class org.apache.hadoop.hbase.regionserver.ShutdownHook
Key for a long configuration on how much time to wait on the fs shutdown hook.
FS_WITHOUT_SUPPORT_PERMISSION_DEFAULT - Static variable in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
 
FS_WITHOUT_SUPPORT_PERMISSION_KEY - Static variable in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
 
FS_WRITE_HISTO_KEY - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
 
FS_WRITE_TIME_HISTO_DESC - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
 
fsBlockWriter - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Unified version 2 block writer
FSDataInputStreamWrapper - Class in org.apache.hadoop.hbase.io
Wrapper for input stream(s) that takes care of the interaction of FS and HBase checksums, as well as closing streams.
FSDataInputStreamWrapper(FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
 
FSDataInputStreamWrapper(FileSystem, Path, boolean) - Constructor for class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
 
FSDataInputStreamWrapper(FileSystem, FileLink) - Constructor for class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
 
FSDataInputStreamWrapper(FileSystem, FileLink, boolean) - Constructor for class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
 
FSDataInputStreamWrapper(FSDataInputStream) - Constructor for class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
For use in tests.
FSDataInputStreamWrapper(FSDataInputStream, FSDataInputStream) - Constructor for class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
For use in tests.
FsDelegationToken - Class in org.apache.hadoop.hbase.security.token
Helper class to obtain a filesystem delegation token.
FsDelegationToken(UserProvider, String) - Constructor for class org.apache.hadoop.hbase.security.token.FsDelegationToken
 
FSHDFSUtils - Class in org.apache.hadoop.hbase.util
Implementation for hdfs
FSHDFSUtils() - Constructor for class org.apache.hadoop.hbase.util.FSHDFSUtils
 
FSHLog - Class in org.apache.hadoop.hbase.regionserver.wal
Implementation of WAL to go against FileSystem; i.e.
FSHLog(FileSystem, Path, String, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.FSHLog
Constructor.
FSHLog(FileSystem, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.FSHLog
Create an edit log at the given dir location.
FSMapRUtils - Class in org.apache.hadoop.hbase.util
MapR implementation.
FSMapRUtils() - Constructor for class org.apache.hadoop.hbase.util.FSMapRUtils
 
fsOk - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
FSTableDescriptorMigrationToSubdir - Class in org.apache.hadoop.hbase.util
Deprecated.
will be removed for the major release after 0.96.
FSTableDescriptorMigrationToSubdir() - Constructor for class org.apache.hadoop.hbase.util.FSTableDescriptorMigrationToSubdir
Deprecated.
 
FSTableDescriptors - Class in org.apache.hadoop.hbase.util
Implementation of TableDescriptors that reads descriptors from the passed filesystem.
FSTableDescriptors(Configuration) - Constructor for class org.apache.hadoop.hbase.util.FSTableDescriptors
Construct a FSTableDescriptors instance using the hbase root dir of the given conf and the filesystem where that root dir lives.
FSTableDescriptors(Configuration, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.util.FSTableDescriptors
 
FSTableDescriptors(Configuration, FileSystem, Path, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.util.FSTableDescriptors
 
FSUtils - Class in org.apache.hadoop.hbase.util
Utility methods for interacting with the underlying file system.
FSUtils() - Constructor for class org.apache.hadoop.hbase.util.FSUtils
 
FSUtils.BlackListDirFilter - Class in org.apache.hadoop.hbase.util
Directory filter that doesn't include any of the directories in the specified blacklist
FSUtils.BlackListDirFilter(FileSystem, List<String>) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
Create a filter on the givem filesystem with the specified blacklist
FSUtils.DirFilter - Class in org.apache.hadoop.hbase.util
A PathFilter that only allows directories.
FSUtils.DirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.DirFilter
 
FSUtils.FamilyDirFilter - Class in org.apache.hadoop.hbase.util
Filter for all dirs that are legal column family names.
FSUtils.FamilyDirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.FamilyDirFilter
 
FSUtils.HFileFilter - Class in org.apache.hadoop.hbase.util
Filter for HFiles that excludes reference files.
FSUtils.HFileFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.HFileFilter
 
FSUtils.HFileLinkFilter - Class in org.apache.hadoop.hbase.util
Filter for HFileLinks (StoreFiles and HFiles not included).
FSUtils.HFileLinkFilter() - Constructor for class org.apache.hadoop.hbase.util.FSUtils.HFileLinkFilter
 
FSUtils.ReferenceFileFilter - Class in org.apache.hadoop.hbase.util
 
FSUtils.ReferenceFileFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.ReferenceFileFilter
 
FSUtils.RegionDirFilter - Class in org.apache.hadoop.hbase.util
Filter for all dirs that don't start with '.'
FSUtils.RegionDirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
 
FSUtils.UserTableDirFilter - Class in org.apache.hadoop.hbase.util
A PathFilter that returns usertable directories.
FSUtils.UserTableDirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.UserTableDirFilter
 
FSVisitor - Class in org.apache.hadoop.hbase.util
Utility methods for interacting with the hbase.root file system.
FSVisitor.StoreFileVisitor - Interface in org.apache.hadoop.hbase.util
 
FULL_RWX_PERMISSIONS - Static variable in class org.apache.hadoop.hbase.util.FSUtils
Full access permissions (starting point for a umask)
fullScan(Connection, MetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of hbase:meta.
fullScan(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of hbase:meta.
fullScan(Connection, MetaTableAccessor.Visitor, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of a catalog table.
fullScanMetaAndPrint(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
fullScanOfMeta(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Performs a full scan of a hbase:meta table.
fullyQualifiedZNode - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
 
fuzzyMatch(String) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
 
fuzzyNormalize(String) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
 
FuzzyRowFilter - Class in org.apache.hadoop.hbase.filter
This is optimized version of a standard FuzzyRowFilter Filters data based on fuzzy row key.
FuzzyRowFilter(List<Pair<byte[], byte[]>>) - Constructor for class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 

G

Gauge<T> - Interface in org.apache.hadoop.hbase.metrics
A metrics which measures a discrete value.
GENERAL_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
GENERAL_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
generalBloomFilter - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
GeneralBulkAssigner - Class in org.apache.hadoop.hbase.master
Run bulk assign.
GeneralBulkAssigner(Server, Map<ServerName, List<HRegionInfo>>, AssignmentManager, boolean) - Constructor for class org.apache.hadoop.hbase.master.GeneralBulkAssigner
 
generateDeadServersListToSend() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
Create the dead server to send.
generateExceptionForChecksumFailureForTest(boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
Mechanism to throw an exception in case of hbase checksum failure.
generateNewScannerId() - Method in class org.apache.hadoop.hbase.regionserver.ScannerIdGenerator
 
generateToken(String) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
Get - Class in org.apache.hadoop.hbase.client
Used to perform Get operations on a single row.
Get(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Get
Create a Get operation for the specified row.
Get(Get) - Constructor for class org.apache.hadoop.hbase.client.Get
Copy-constructor
get() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
get(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
get(Get) - Method in class org.apache.hadoop.hbase.client.HTable
Extracts certain cells from a given row.
get(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
Extracts certain cells from the given rows, in batch.
get(Get) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
get(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Returns a list of all KeyValue objects with matching column family and qualifier.
get - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
get(Get) - Method in interface org.apache.hadoop.hbase.client.Table
Extracts certain cells from a given row.
get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
Extracts certain cells from the given rows, in batch.
get() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
Currently unused.
get(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
get(String, String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
Get the value of the name.
get(int) - Static method in enum org.apache.hadoop.hbase.executor.EventType
 
get(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
Create a new HFileSystem object, similar to FileSystem.get().
get() - Method in class org.apache.hadoop.hbase.hbtop.field.Size
get the value
get(Size.Unit) - Method in class org.apache.hadoop.hbase.hbtop.field.Size
get the value which is converted to specified unit.
get(Object) - Method in class org.apache.hadoop.hbase.hbtop.Record
 
get(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
get() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Get the data from the BytesWritable.
get() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
Returns the parameter passed to BlockingRpcCallback.run(Object) or null if a null value was passed.
get() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
get(long, TimeUnit) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
get(String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
get(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
 
get(String) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
get(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
Returns the MetricRegistry if found.
get(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
Returns previously registered metric with the name if any.
get() - Static method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
Get singleton instance.
get(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
get(Get) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
get(Get, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
get(Get, boolean, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
get(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Retrieves the value associated with the specified key.
get(Get) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Do a get based on the get parameter.
get(Get, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Do a get based on the get parameter.
get(Get, boolean, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Do a get for duplicate non-idempotent operation.
get(RpcController, ClientProtos.GetRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Get data from a table.
get - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
get(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a GET request
get(Cluster, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a GET request
get(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a GET request
get(Cluster, String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a GET request
get(String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a GET request
get(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a GET request
get(Get) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
get(List<Get>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ExistsResource
 
get(int) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
 
get(int) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.MultiRowResource
 
get(ServletContext, UriInfo) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
Build a response for GET namespace description or GET list of namespace tables.
get(ServletContext, UriInfo) - Method in class org.apache.hadoop.hbase.rest.NamespacesResource
Build a response for a list of all namespaces request.
get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RegionsResource
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RootResource
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
 
get(UriInfo, int, int) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.StorageClusterStatusResource
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.StorageClusterVersionResource
 
get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.TableScanResource
 
get(ServletContext, UriInfo) - Method in class org.apache.hadoop.hbase.rest.VersionResource
Build a response for a version request.
get() - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
 
get(TableName) - Method in interface org.apache.hadoop.hbase.TableDescriptors
 
get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get a single TCell for the specified table, row, and column at the latest timestamp.
get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
get(ByteBuffer, ByteBuffer, byte[], byte[], Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Note: this internal interface is slightly different from public APIs in regard to handling of the qualifier.
get(ByteBuffer, TGet, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
get(ByteBuffer, TGet, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
get(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
get(ByteBuffer, TGet) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Method for getting data from a row.
get(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
get(String) - Method in class org.apache.hadoop.hbase.trace.HBaseHTraceConfiguration
 
get(String, String) - Method in class org.apache.hadoop.hbase.trace.HBaseHTraceConfiguration
 
get(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
get(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
get() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
get(byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
get(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
get(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Retrieve the byte at index.
get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Fill dst with bytes from the range, starting from index.
get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Fill dst with bytes from the range, starting from index.
get() - Method in class org.apache.hadoop.hbase.util.Bytes
Get the data from the Bytes.
get() - Method in class org.apache.hadoop.hbase.util.Counter
 
get(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Get the current table descriptor for the given table, or null if none exists.
get(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
get() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
get() - Method in class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
 
get() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Retrieve the next byte from this range.
get(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Fill dst with bytes from the range, starting from position.
get(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Fill dst with bytes from the range, starting from the current position.
get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
get() - Method in class org.apache.hadoop.hbase.util.SortedList
Returns a reference to the unmodifiable list currently backing the SortedList.
get(int) - Method in class org.apache.hadoop.hbase.util.SortedList
 
get(K) - Method in class org.apache.hadoop.hbase.util.WeakObjectPool
Returns a shared object associated with the given key, which is identified by the equals method.
get(String) - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
 
get(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Get a metric by name
get25thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Returns the value at the 25th percentile in the distribution.
get75thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
 
get75thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Returns the value at the 75th percentile in the distribution.
get90thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Returns the value at the 90th percentile in the distribution.
get95thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
 
get95thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Returns the value at the 95th percentile in the distribution.
get98thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
 
get98thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Returns the value at the 98th percentile in the distribution.
get999thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
 
get999thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Returns the value at the 99.9th percentile in the distribution.
get99thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
 
get99thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Returns the value at the 99th percentile in the distribution.
GET_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
GET_SIZE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
GET_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
 
getAbortable() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
getAbortNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
Get the full znode path for the node used by the coordinator or member to trigger an abort of the global barrier acquisition or execution in subprocedures.
getAbortZNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
getAbortZnode() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
getAbsoluteFamilyOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getAbsoluteMetaOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
absolute getters
getAbsoluteMvccVersionOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getAbsoluteQualifierOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getAbsoluteRowOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getAbsoluteTagsOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getAbsoluteTimestampOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getAbsoluteValueOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getACL() - Method in class org.apache.hadoop.hbase.client.Mutation
 
getACL() - Method in class org.apache.hadoop.hbase.client.Query
 
getAcl(String, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getAcl is an idempotent operation.
getAcquireBarrierNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
Get the full znode path for the node used by the coordinator to trigger a global barrier acquire on each subprocedure.
getAcquiredBarrier() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
getAcquiredBarrierNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
getAction() - Method in class org.apache.hadoop.hbase.client.Action
 
getAction() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
getActions() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
 
getActions() - Method in class org.apache.hadoop.hbase.security.access.Permission
 
getActiveExecutorCount() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
getActiveHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
getActiveHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
getActiveLogFiles() - Static method in class org.apache.hadoop.hbase.monitoring.LogMonitoring
 
getActiveLogs() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
getActiveMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Gets the current active master, if available.
getActiveReadHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
getActiveReadHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
getActiveReadRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Retrieves the number of active write rpc handler when use RWQueueRpcExecutor.
getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
getActiveRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Retrieves the number of active handler.
getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
getActiveScanHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
getActiveScanHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
getActiveScanRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Retrieves the number of active write rpc handler when use RWQueueRpcExecutor.
getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
getActiveTime() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get the hbase master active time
getActiveTime() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getActiveUser() - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
 
getActiveWriteHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
getActiveWriteHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
getActiveWriteRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Retrieves the number of active write rpc handler when use RWQueueRpcExecutor.
getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
getAddress() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
getAddress() - Method in class org.apache.hadoop.hbase.ServerName
 
getAdmin(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Establishes a connection to the region server at the specified address.
getAdmin() - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve an Admin implementation to administer an HBase cluster.
getAdmin() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
getAdmin() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an Admin implementation to administer an HBase cluster.
getAdmin(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getAdmin(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
You can pass master flag but nothing special is done.
getAdmin() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to get the Admin.
getAdmin() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
Caller doesn't close the admin afterwards.
getAgeAtEvictionSnapshot() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getAgeInCacheSnapshot() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
 
getAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
Get the Age of Last Applied Op
getAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Get AgeOfLastShippedOp
getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getAggregateRequestPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
 
getAggregateSource() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
Get the aggregate source to which this reports.
getAggregateSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
getAggregateSource() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
Get the aggregate source to which this reports.
getAggregateSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
getAliasPassword(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
getAll() - Method in interface org.apache.hadoop.hbase.TableDescriptors
Get Map of all HTableDescriptors.
getAll() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Returns a map from table name to table descriptor for all tables.
getAllCached() - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
 
getAllExecutorStatuses() - Method in class org.apache.hadoop.hbase.executor.ExecutorService
 
getAllFilters() - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns all known filters
getAllocator() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getAllowPartialResults() - Method in class org.apache.hadoop.hbase.client.Scan
 
getAllPeerConfigs() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
List the cluster replication configs of all remote slave clusters (whether they are enabled/disabled or connected/disconnected).
getAllPeerConfigs() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getAllPeerIds() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
List the peer ids of all remote slave clusters (whether they are enabled/disabled or connected/disconnected).
getAllPeerIds() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
List all registered peer clusters and set a watch on their znodes.
getAllPeersFromHFileRefsQueue() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get list of all peers from hfile reference queue.
getAllPeersFromHFileRefsQueue() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getAllQueues() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Get a list of all queues for this region server.
getAllQueues(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get a list of all queues for the specified region server.
getAllQueues(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getAllQueues() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getAllRegionLocations() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
 
getAllRegionLocations() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
getAllRegionLocations() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Retrieves all of the regions associated with this table.
getAllRegionLocations(ByteBuffer, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
getAllRegionLocations(ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
getAllRegionLocations(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
getAllRegionLocations(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Get all of the region locations for a given table.
getAllRegionLocations(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
getAllSameTypeByte() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getAllTypes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getAlphabet(int) - Static method in class org.apache.hadoop.hbase.util.Base64
Returns one of the _SOMETHING_ALPHABET byte arrays depending on the options specified.
getAlterStatus(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
getAlterStatus(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
getAlterStatus(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
getAlterStatus(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
getAmmount() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
getAmount() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
getAndRemoveScopes() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
getAndResetChecksumFailuresCount() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Number of checksum verification failures.
getAnnotatedPriority(RPCProtos.RequestHeader) - Method in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
See if the method has an annotation.
getAny() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
getAny() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
getAppend() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
The single append operation to apply
getArchivedStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
getArchivedStoreFileSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
getArchivePath() - Method in class org.apache.hadoop.hbase.io.HFileLink
 
getArchivePath(Configuration) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
Get the full path to the archive directory on the configured MasterFileSystem
getArchiveZNode(Configuration, ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
 
getArchivingEnabled(byte[]) - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
Determine if archiving is enabled (but not necessarily fully propagated) for a table
getArchivingEnabled(String) - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
Determine if archiving is enabled (but not necessarily fully propagated) for a table
getArrayOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getArrays() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
getAssignmentManager() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getAssignmentManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getAssignmentManager() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
 
getAssignmentManager() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getAssignmentManager__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getAssignmentMap() - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
 
getAssignmentsByTable() - Method in class org.apache.hadoop.hbase.master.RegionStates
This is an EXPENSIVE clone.
getAsyncClient(TNonblockingTransport) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.Factory
 
getAsyncProcess() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getAttemptTimes() - Method in class org.apache.hadoop.hbase.util.RetryCounter
 
getAttribute(String) - Method in interface org.apache.hadoop.hbase.client.Attributes
Gets an attribute
getAttribute(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
getAttribute(String) - Method in class org.apache.hadoop.hbase.http.HttpServer
Get the value in the webapp context.
getAttribute(String) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
getAttribute(String) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
Return a table descriptor value as a string.
getAttributes() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
Mutation attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
Delete attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
Delete attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
Delete attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
Delete attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
Get attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
Get attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
Get attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
Get attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
Get attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
Get attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
Get attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
Get attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
Get attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
Get attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
Get attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
Mutation attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
Mutation attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
Mutation attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
Mutation attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
Scan attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
Scan attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
Scan attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
Scan attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
Scan attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Scan attributes
getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getAttributeSize() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
getAttributesKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
getAttributesMap() - Method in interface org.apache.hadoop.hbase.client.Attributes
Gets all attributes
getAttributesMap() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrs(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrs(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAttrsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
getAuthChore(Configuration) - Static method in class org.apache.hadoop.hbase.AuthUtil
Checks if security is enabled and if so, launches chore for refreshing kerberos ticket.
getAuthenticationToken(RpcController, AuthenticationProtos.GetAuthenticationTokenRequest, RpcCallback<AuthenticationProtos.GetAuthenticationTokenResponse>) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
 
getAuthManager() - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
 
getAuthManager() - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
getAuthorizations() - Method in class org.apache.hadoop.hbase.client.Query
 
getAuthorizations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getAuthorizations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getAuths(byte[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
Deprecated.
getAuths(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
getAuths(Connection, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
 
getAuths(RpcController, VisibilityLabelsProtos.GetAuthsRequest, RpcCallback<VisibilityLabelsProtos.GetAuthsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
getAuths(byte[], boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
getAvailable() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
 
getAvailablePath(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
 
getAverageLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.master.HMaster
Compute the average load across all region servers.
getAverageLoad() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get Average Load
getAverageLoad() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.master.RegionStates
Compute the average load across all region servers.
getAverageLoad() - Method in class org.apache.hadoop.hbase.master.ServerManager
Compute the average load across all region servers.
getAverageLoad() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional double averageLoad = 5;
getAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
optional double averageLoad = 5;
getAverageLoad() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
optional double averageLoad = 5;
getAverageRegionSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the average region size to this region server.
getAvg(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
Gives a Pair with first object as Sum and second object as row count, computed for a given combination of column qualifier and column family in the given row range as defined in the Scan object.
getAvgSize() - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
getAvgStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getAvgStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getAvgStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
 
getAvgStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getAvgStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getBackgroundColor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
getBackgroundColor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
getBackingFs() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
Returns the underlying filesystem
getBackoffPolicy() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getBackoffPolicy() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
 
getBackoffTime(ServerName, byte[], ServerStatistics) - Method in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
 
getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
 
getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
getBackoffTime(RetryCounter.RetryConfig, int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.BackoffPolicy
 
getBackoffTime(RetryCounter.RetryConfig, int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicy
 
getBackoffTime(RetryCounter.RetryConfig, int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicyWithLimit
 
getBackReferenceFileName(Path) - Static method in class org.apache.hadoop.hbase.io.FileLink
Get the referenced file name from the reference link directory path.
getBackReferencesDir(Path, String) - Static method in class org.apache.hadoop.hbase.io.FileLink
Get the directory to store the link back references
getBackupMasterInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get the info port of the backup master if it is available.
getBackupMasters() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getBackupMastersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getBackupZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
 
getBalancer(int) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
getBalancer() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
getBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getBandwidth() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getBaseOffset() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
getBasePriority(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
Get the priority for a given request from the header and the param This doesn't consider which user is sending the request at all.
getBaseStagingDir(Configuration) - Static method in class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
 
getBaseZnode() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
getBaseZNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getBatch() - Method in class org.apache.hadoop.hbase.client.Scan
 
getBatch() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
 
getBatch() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
getBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 batch = 4;
getBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int32 batch = 4;
getBatch() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int32 batch = 4;
getBatchSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
getBatchSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getBcn() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
 
getBcn() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
getBcn__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
getBcv() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
 
getBcv() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
getBcv__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
getBestLocations(Configuration, HDFSBlocksDistribution) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
This computes the locations to be passed from the InputSplit.
getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
 
getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
 
getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Fetch block from cache.
getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
Get the buffer of the block with the specified key.
getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
 
getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the buffer of the block with the specified name.
getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
getBlockCache() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Returns the block cache.
getBlockCacheCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of items in the block cache.
getBlockCacheEvictedCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of items evicted from the block cache.
getBlockCacheFailedInsertions() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Number of cache insertions that failed.
getBlockCacheFreeSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the size (in bytes) of the block cache that is free.
getBlockCacheHeapPercent(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
Retrieve configured size for on heap block cache as percentage of total heap.
getBlockCacheHitCachingPercent() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the percent of requests with the block cache turned on that hit the block cache.
getBlockCacheHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the count of hits to the block cache
getBlockCacheHitPercent() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the percent of all requests that hit the block cache.
getBlockCacheMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the count of misses to the block cache.
getBlockCachePrimaryEvictedCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of items evicted from primary replica in the block cache.
getBlockCachePrimaryHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the count of hits to primary replica in the block cache
getBlockCachePrimaryMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the count of misses to primary replica in the block cache.
getBlockCaches() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
 
getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
getBlockCacheSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
 
getBlockCacheSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the total size (in bytes) of the block cache.
getBlockCount() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Returns the number of blocks currently cached in the block cache.
getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
getBlockedFlushCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
getBlockedRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getBlockedRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getBlockedRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getBlockingFileCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getBlockingFileCount() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
The number of files required before flushes for this store will be blocked.
getBlockingService() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
 
getBlockLocalityIndex(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
return the locality index of a given host
getBlockMeta() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
getBlockMeta() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
get/set
getBlockPriority() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
 
getBlocksize() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getBlockSize() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
 
getBlockSize() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
 
getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
Get the cipher's internal block size
getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Get the cipher's internal block size
getBlocksize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
getBlockType() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
getBlockType() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
 
getBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
 
getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
 
getBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getBloomBlockSize(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
 
getBloomChunkHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getBloomChunkHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getBloomChunkHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getBloomChunkMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getBloomChunkMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getBloomChunkMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getBloomFilterNbHashes() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
getBloomFilterType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getBloomFilterType() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getBloomFilterType() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
getBloomFilterVectorSize() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
getBnlIndicator(boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
 
getBoolean(String, boolean) - Method in class org.apache.hadoop.hbase.trace.HBaseHTraceConfiguration
 
getBoundaries() - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionRequest
 
getBoundedCachedThreadPool(int, long, TimeUnit, ThreadFactory) - Static method in class org.apache.hadoop.hbase.util.Threads
Create a new CachedThreadPool with a bounded number as the maximum thread size in the pool.
getBranchNubLeafIndicator() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getBucketCacheSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
 
getBucketIndex(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
getBuckets() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
getBucketSize() - Method in class org.apache.hadoop.hbase.util.LossyCounting
 
getBuffer() - Method in class org.apache.hadoop.hbase.io.BoundedByteBufferPool
 
getBuffer() - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
 
getBuffer() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
getBuffer() - Method in class org.apache.hadoop.hbase.KeyValue
Deprecated.
Since 0.98.0. Use Cell Interface instead. Do not presume single backing buffer.
getBuffer() - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
 
getBuffer() - Method in class org.apache.hadoop.hbase.Tag
 
getBufferedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getBufferedMutator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a BufferedMutator for performing client-side buffering of writes.
getBufferedMutator(BufferedMutatorParams) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a BufferedMutator for performing client-side buffering of writes.
getBufferOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getBufferReadOnly() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Returns a read-only duplicate of the buffer this block stores internally ready to be read.
getBufferWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Returns a buffer that does not include the header or checksum.
getBuilder(WALCellCodec.ByteStringCompressor) - Method in class org.apache.hadoop.hbase.wal.WALKey
 
getBulkLoadDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
Deserialized and returns a BulkLoadDescriptor from the passed in Cell
getBulkLoadTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
Return the timestamp at which this bulk load file was generated.
getByNamespace(String) - Method in interface org.apache.hadoop.hbase.TableDescriptors
Get Map of all NamespaceDescriptors for a given namespace.
getByNamespace(String) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
 
getByteArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
getByteBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
This flips the underlying BB so be sure to use it _last_!
getBytes() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
getBytes() - Method in interface org.apache.hadoop.hbase.util.ByteRange
The underlying byte[].
getBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
Returns a new byte array, copied from the given buf, from the position (inclusive) to the limit (exclusive).
getBytes() - Method in class org.apache.hadoop.hbase.util.HashedBytes
 
getBytes(int, long) - Static method in class org.apache.hadoop.hbase.util.vint.UFIntTool
 
getBytes(int) - Static method in class org.apache.hadoop.hbase.util.vint.UVIntTool
 
getBytes(long) - Static method in class org.apache.hadoop.hbase.util.vint.UVLongTool
 
getBytes(Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
 
getBytes(Writable...) - Static method in class org.apache.hadoop.hbase.util.Writables
Put a bunch of Writables as bytes all into the one byte array.
getByteSize() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
 
getByteSize() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
getByteSize() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
 
getBytesPerChecksum() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
getBytesPerChecksum(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
Returns the configured bytesPerChecksum value.
getBytesPerDelta() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
getBytesPerIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
getBytesPerSec() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
Getter for the read-rate from this stream, since creation.
getByteStream() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getByteStringCompressor() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
 
getByteStringUncompressor() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
 
getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Get
Get whether blocks should be cached for this Get.
getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Scan
Get whether blocks should be cached for this Scan.
getCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
getCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bool cacheBlocks = 11;
getCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional bool cacheBlocks = 11;
getCacheBlocks() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional bool cacheBlocks = 11;
getCacheConfig() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getCacheConfig() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getCacheConfig() - Method in interface org.apache.hadoop.hbase.regionserver.Store
Used for tests.
getCacheConfig() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.ImplData
 
getCacheConfig() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
 
getCachedBlockStatsByFile() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
 
getCachedLocation(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
Search the cache for a location that fits our table and row key.
getCachedTime() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
 
getCachedTime() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
getCacheKey() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
getCacheMissCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
getCacheOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
 
getCacheOnWrite() - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
 
getCacheOnWrite() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
 
getCacheSize() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getCaching() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getCaching() - Method in class org.apache.hadoop.hbase.client.Scan
 
getCaching() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Get the number of rows that will be fetched on next
getCaching() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
getCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 caching = 9;
getCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int32 caching = 9;
getCaching() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int32 caching = 9;
getCaching() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
getCaching() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getCall() - Method in class org.apache.hadoop.hbase.ipc.CallRunner
 
getCallRunner() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor.Handler
 
getCallTimeMs() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
getCallTimeout() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
 
getCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
getCandidateFilesForRowKeyBefore(KeyValue) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Gets initial, full list of candidate store files to check for row-key-before.
getCandidateFilesForRowKeyBefore(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
getCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getCatalogJanitorEnabled__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getCategory() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
 
getCause(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getCause() - Method in exception org.apache.hadoop.hbase.thrift.ThriftServerRunner.IOErrorWithCause
 
getCauses() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getCell() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
getCellBufSize() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
getCellBufSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
getCellBufSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
 
getCellKeyAsString(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
getCellKeySerializedAsKeyValueKey(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
This method exists just to encapsulate how we serialize keys.
getCellPermissionsForUser(User, Cell) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
 
getCells() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
getCells() - Method in class org.apache.hadoop.hbase.rest.model.RowModel
 
getCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
 
getCellTTLColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
getCellValueFromProto(HBaseProtos.BigDecimalMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getCellValueFromProto(HBaseProtos.DoubleMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getCellValueFromProto(HBaseProtos.LongMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getCellValueFromProto(Q) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method gets the PB message corresponding to the cell type
getCellVisibility() - Method in class org.apache.hadoop.hbase.client.Mutation
 
getCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
getCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
getCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
getCellVisibilityColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
getChance() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
getChannel() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService.Stub
 
getChannel() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.Stub
 
getChar() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
getCharacter() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
 
getCheckAndMutateChecksFailed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getCheckAndMutateChecksFailed() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of CAS operations that failed.
getCheckAndMutateChecksFailed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getCheckAndMutateChecksPassed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getCheckAndMutateChecksPassed() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of CAS operations that passed.
getCheckAndMutateChecksPassed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getChecksumFailures() - Method in interface org.apache.hadoop.hbase.io.MetricsIOWrapper
 
getChecksumFailures() - Method in class org.apache.hadoop.hbase.io.MetricsIOWrapperImpl
 
getChecksumFailuresCount() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Number of checksum verification failures.
getChecksumType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
getChecksumType(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
Returns the configured checksum algorithm.
getChildDataAndWatchForNewChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Deprecated.
Unused
getChildExps() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
 
getChildren() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getChildren(String, Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getChildren is an idempotent operation.
getChildren(String, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getChildren is an idempotent operation.
getChildSequenceId(String) - Static method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.ZNodeComparator
Parses sequenceId from the znode name.
getChoreService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getChoreService() - Method in interface org.apache.hadoop.hbase.Server
 
getCipher(String) - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
Get an Cipher
getCipher() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
getCipher(String) - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
 
getCipher(Configuration, String) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Get an cipher given a name
getCipherProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
getClassByName(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
getClassLoader() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
 
getClassLoader() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getClassLoader(Path, ClassLoader, String, Configuration) - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
Get a CoprocessorClassLoader for a coprocessor jar path from cache.
getClassLoadingLock(String) - Method in class org.apache.hadoop.hbase.util.ClassLoaderBase
Returns the lock object for class loading operations.
getCleanerThreads() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
getClient(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Establishes a connection to the region server at the specified address, and returns a region client protocol.
getClient(ServerName) - Method in class org.apache.hadoop.hbase.client.CoprocessorHConnection
 
getClient(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getClient() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
 
getClient() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
If an RPC call is currently running, produces a String representation of the connection from which it was received.
getClient(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client.Factory
 
getClientAckTime() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.ZKConfig.ZKClusterKey
 
getClientPortList() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
Get the list of client ports.
getClientVersionInfo() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
 
getClientVersionInfo() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
getCloseCheckInterval() - Static method in class org.apache.hadoop.hbase.regionserver.HStore
 
getCloseRegionCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
Method to retrieve coordination for closing region operations.
getCloseRegionCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
getClosestRowBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getClosestRowBefore(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Return all the data for the row that matches row exactly, or the one that immediately preceeds it, at or immediately before ts.
getCluster() - Method in class org.apache.hadoop.hbase.rest.client.Client
 
getClusterId() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getClusterId() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
 
getClusterId() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
getClusterId() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get the Cluster ID
getClusterId() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getClusterId() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getClusterId() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the Cluster ID
getClusterId() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
getClusterId(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Returns the value of the unique cluster ID stored for this HBase instance.
getClusterIds() - Method in class org.apache.hadoop.hbase.client.Mutation
 
getClusterIds() - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
 
getClusterIds() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
 
getClusterIds() - Method in class org.apache.hadoop.hbase.wal.WALKey
 
getClusterKey() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getClusterStatus() - Method in interface org.apache.hadoop.hbase.client.Admin
 
getClusterStatus() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getClusterStatus() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getClusterStatus(RpcController, MasterProtos.GetClusterStatusRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
getClusterStatus() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
getClusterStatusResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
 
getClusterStatusWithoutCoprocessor() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getClusterVersion() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
getClusterVersionResource() - Method in class org.apache.hadoop.hbase.rest.VersionResource
Dispatch to StorageClusterVersionResource
getCode() - Method in enum org.apache.hadoop.hbase.executor.EventType
 
getCode() - Method in enum org.apache.hadoop.hbase.KeyValue.Type
 
getCode() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
 
getCode() - Method in class org.apache.hadoop.hbase.rest.client.Response
 
getCode() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
 
getCodec(Configuration, String, CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
getCodec(Configuration, CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
getCodec(Configuration, Encryptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
 
getCodec(Configuration, Decryptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
 
getCodecClsName() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
getColFamTimeRangeMap() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getColFamTimeRangeMapSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Deprecated.
getColumn() - Method in class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
 
getColumn() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
 
getColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes column = 2;
getColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
optional bytes column = 2;
getColumn() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
optional bytes column = 2;
getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
name of column
getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
column name
getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
name of column whose value is to be deleted
getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
name of column whose value is to be deleted
getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
column name
getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
column name
getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
column name
getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
getColumnCells(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Return the Cells for the specific column.
getColumnDescriptors(ByteBuffer, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getColumnDescriptors(ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getColumnDescriptors(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getColumnDescriptors(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
List all the column families assoicated with a table.
getColumnDescriptors(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getColumnFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns an array all the HColumnDescriptor of the column families of the table.
getColumnFamilies() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
list of column family descriptors
getColumnFamiliesIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
getColumnFamiliesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
getColumnFamily(int) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
Retrieve the column family at the given index from the table descriptor
getColumnFamilyName() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getColumnFamilyName() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getColumnFamilyTimeRange() - Method in class org.apache.hadoop.hbase.client.Query
 
getColumnHint() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
Used by matcher and scan/get to get a hint of the next column to seek to after checkColumn() returns SKIP.
getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
 
getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
Used by matcher and scan/get to get a hint of the next column to seek to after checkColumn() returns SKIP.
getColumnLatest(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
getColumnLatest(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
getColumnLatestCell(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
The Cell for the most recent timestamp for a given column.
getColumnLatestCell(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
The Cell for the most recent timestamp for a given column.
getColumnLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
 
getColumnName() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
getColumnNodeWriters() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
get/set
getColumnOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
get/set
getColumnOffset(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getColumnOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getColumns() - Method in class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
 
getColumns() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
getColumns() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated bytes columns = 3;
getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
repeated bytes columns = 3;
getColumns(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
repeated bytes columns = 3;
getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumns(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumns() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
List of columns to return, null for all columns
getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
List of columns to return, null for all columns
getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
List of columns to return, null for all columns
getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
List of columns to return, null for all columns
getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
columns to scan.
getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
columns to scan.
getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
the columns you want returned
getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
columns to scan.
getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
columns to scan.
getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getColumnsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated bytes columns = 3;
getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
repeated bytes columns = 3;
getColumnsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
repeated bytes columns = 3;
getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated bytes columns = 3;
getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
repeated bytes columns = 3;
getColumnsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
repeated bytes columns = 3;
getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getColumnValues() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
getColumnValues() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
getColumnValuesIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
getColumnValuesIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
getColumnValuesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
getColumnValuesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
getCompactedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of cells processed during minor compactions.
getCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getCompactedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the total amount of data processed during minor compactions, in bytes.
getCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getCompactedfiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getCompactedfiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
List of compacted files inside this store that needs to be excluded in reads because further new reads will be using only the newly created files out of compaction.
getCompactedfiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getCompaction(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
Deserialized and returns a CompactionDescriptor is the KeyValue contains one.
getCompactionCheckMultiplier() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getCompactionCheckMultiplier() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
 
getCompactionCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompactionCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompactionPolicy() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
getCompactionPolicyForDateTieredWindow() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getCompactionPressure() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
getCompactionPressure() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getCompactionPressure() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getCompactionPressure() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getCompactionPressure() - Method in interface org.apache.hadoop.hbase.regionserver.Store
This value can represent the degree of emergency of compaction for this store.
getCompactionPressure() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
 
getCompactionPressure() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getCompactionProgress() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getCompactionProgress() - Method in interface org.apache.hadoop.hbase.regionserver.Store
getter for CompactionProgress object
getCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
Returns the current size of the queue containing regions that are processed.
getCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the size of the compaction queue
getCompactionRatio() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getCompactionRatioOffPeak() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getCompactionRequester() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getCompactionRequester() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getCompactionState(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the current compaction state of a table.
getCompactionState(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get the current compaction state of a table.
getCompactionState(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
getCompactionState(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
getCompactionState() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getCompactionState() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getCompactionStateForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
getCompactionStateForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get the current compaction state of region.
getCompactionThroughputController() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
getCompactor() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
getCompactPriority() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getCompactPriority() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getCompactPriority() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getCompactSplitThread() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getComparator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
getComparator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getComparator() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getComparator() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getComparator() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getComparator() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getComparator() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getComparator() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
 
getComparator() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
 
getComparator() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getComparator() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getComparator() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getComparator() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
 
getComparator() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
getComparator() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
 
getComparator() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
 
getComparatorClassName() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getCompareOp() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
comparison to make on the value
getComparisonData() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
getCompletedSnapshotDir(HBaseProtos.SnapshotDescription, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Get the directory for a specified snapshot.
getCompletedSnapshotDir(String, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Get the directory for a completed snapshot.
getCompletedSnapshots(RpcController, MasterProtos.GetCompletedSnapshotsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
List the currently available/stored snapshots.
getCompletedSnapshots() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Gets the list of all completed snapshots.
getCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
This does not really belong inside RegionLoad but its being done in the name of expediency.
getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
 
getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
 
getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
getCompletionTimestamp() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
 
getCompletionTimestamp() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
getCompressedSize(Compression.Algorithm, Compressor, byte[], int, int) - Static method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
Find the size of compressed data assuming that buffer will be compressed using given algorithm.
getCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompression() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
getCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string compression = 5;
getCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional string compression = 5;
getCompression() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional string compression = 5;
getCompression() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
getCompressionAlgorithm() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getCompressionAlgorithm() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getCompressionAlgorithmByName(String) - Static method in class org.apache.hadoop.hbase.io.compress.Compression
 
getCompressionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string compression = 5;
getCompressionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional string compression = 5;
getCompressionBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional string compression = 5;
getCompressionCodec() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
getConcurrentCallsPerServer() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getConf() - Method in class org.apache.hadoop.hbase.BaseConfigurable
 
getConf() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getConf() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
getConf() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
 
getConf() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getConf() - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
 
getConf() - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Returns the current configuration.
getConf() - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
Returns the current configuration.
getConf() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
Returns the current configuration.
getConf() - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Returns the current configuration.
getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
 
getConf() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
getConf() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
 
getConf() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
 
getConf() - Method in class org.apache.hadoop.hbase.regionserver.NoOpHeapMemoryTuner
 
getConf() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionFactory
 
getConf() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
 
getConf(Configuration, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.DefaultSourceFSConfigurationProvider
 
getConf(Configuration, String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.SourceFSConfigurationProvider
Returns the source cluster file system configuration for the given source cluster replication ID.
getConf() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
getConf() - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
getConf() - Method in class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
 
getConf() - Method in class org.apache.hadoop.hbase.security.visibility.EnforcingScanLabelGenerator
 
getConf() - Method in class org.apache.hadoop.hbase.security.visibility.FeedUserAuthScanLabelGenerator
 
getConf() - Method in class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
 
getConf() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
 
getConf() - Method in class org.apache.hadoop.hbase.tool.CanaryTool
 
getConf() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
getConf() - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
 
getConfig() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.ImplData
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Admin
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Returns the Configuration object used by this instance.
getConfiguration() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Connection
 
getConfiguration() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
 
getConfiguration() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
 
getConfiguration() - Method in class org.apache.hadoop.hbase.client.HTable
Returns the Configuration object used by this instance.
getConfiguration() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Table
Returns the Configuration object used by this instance.
getConfiguration() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getConfiguration() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Getter for fetching an unmodifiable HColumnDescriptor.configuration map.
getConfiguration() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for fetching an unmodifiable HTableDescriptor.configuration map.
getConfiguration() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getConfiguration() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
getConfiguration() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
Getter for fetching an unmodifiable NamespaceDescriptor.configuration map.
getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
 
getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
Get the configuration object required to communicate with this peer
getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Get the configuration object required to communicate with this peer
getConfiguration() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getConfiguration(String, FilterConfig) - Method in class org.apache.hadoop.hbase.rest.filter.AuthFilter
Returns the configuration to be used by the authentication filter to initialize the authentication handler.
getConfiguration() - Method in interface org.apache.hadoop.hbase.Server
Gets the configuration object for this server.
getConfiguration() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getConfigurationManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Getter for accessing the configuration value by key.
getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for accessing the configuration value by key
getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
Getter for accessing the configuration value by key
getConnection() - Method in interface org.apache.hadoop.hbase.client.Admin
 
getConnection() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getConnection() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
getConnection() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
This method will be changed from public to package protected.
getConnection() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getConnection(SocketChannel, long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
Subclasses of HBaseServer can override this to provide their own Connection implementations.
getConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getConnection() - Method in interface org.apache.hadoop.hbase.Server
Returns a reference to the servers' cluster connection.
getConnectionConfiguration() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getConnectionForEnvironment(CoprocessorEnvironment) - Static method in class org.apache.hadoop.hbase.client.CoprocessorHConnection
Create an unmanaged HConnection based on the environment in which we are running the coprocessor.
getConnectionMetrics() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getConnectorAddress(int) - Method in class org.apache.hadoop.hbase.http.HttpServer
Get the address that corresponds to a particular connector.
getConsistency() - Method in class org.apache.hadoop.hbase.client.Query
Returns the consistency level for this operation
getContext() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
 
getContext(Class<?>) - Method in class org.apache.hadoop.hbase.rest.provider.JAXBContextResolver
 
getControllerException(RpcController) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Retreivies exception stored during RPC invocation.
getCoordinatedStateManager(Configuration) - Static method in class org.apache.hadoop.hbase.CoordinatedStateManagerFactory
Creates consensus provider from the given configuration.
getCoordinatedStateManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getCoordinatedStateManager() - Method in interface org.apache.hadoop.hbase.Server
Get CoordinatedStateManager instance for this server.
getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.wal.WAL
 
getCoprocessors() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Used to create a parameter to the HServerLoad constructor so that HServerLoad can provide information about the coprocessors loaded by this regionserver.
getCoprocessors() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Return the list of attached co-processor represented by their name className
getCoprocessors() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get the co-processors
getCoprocessors() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getCoprocessors() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the co-processors
getCorePoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getCorePoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getCorrupted() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
 
getCorruptedLogs() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
getCorruptedStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
getCostFunctionNames() - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
Get the names of the cost functions
getCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
required int64 count = 1 [default = 0];
getCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
required int64 count = 1 [default = 0];
getCount() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponseOrBuilder
required int64 count = 1 [default = 0];
getCount() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
 
getCount() - Method in interface org.apache.hadoop.hbase.metrics.Counter
Returns the current value.
getCount() - Method in interface org.apache.hadoop.hbase.metrics.Histogram
Return the total number of values added to the histogram.
getCount() - Method in class org.apache.hadoop.hbase.metrics.impl.CounterImpl
 
getCount() - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
 
getCount() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
 
getCount() - Method in class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
 
getCount() - Method in interface org.apache.hadoop.hbase.metrics.Meter
Returns the number of events.
getCount() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Returns the number of values in the snapshot.
getCount() - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
getCount() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
Returns the number of items that the estimator has processed
getCountAtOrBelow(long) - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Returns the total count below the given value
getCounter(String) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
getCounter(String, long) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Get a MetricMutableCounterLong from the storage.
getCountersMapSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getCountersMapSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getCreatedTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
getCreateTime() - Method in class org.apache.hadoop.hbase.RegionTransition
 
getCurBlockCacheSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
getCurBlockCacheUsed() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
getCurMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
getCurMemStoreUsed() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
getCurrent() - Static method in class org.apache.hadoop.hbase.security.User
Returns the User instance within current execution context.
getCurrent() - Method in class org.apache.hadoop.hbase.security.UserProvider
 
getCurrentCall() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
Needed for features such as delayed calls.
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getCurrentCompactedKvs() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
 
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 currentCompactedKVs = 13;
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int64 currentCompactedKVs = 13;
getCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int64 currentCompactedKVs = 13;
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getCurrentDataSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Returns the occupied size of data blocks, in bytes.
getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
getCurrentEligibleFiles(ArrayList<StoreFile>, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
 
getCurrentFileName() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
This is a convenience method that computes a new filename with a given using the current WAL file-number
getCurrentFileName(WAL) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
return the current filename from the current wal.
getCurrentFileSystem(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getCurrentHash() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
Get the current hash
getCurrentHour() - Static method in class org.apache.hadoop.hbase.regionserver.compactions.CurrentHourProvider
 
getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
Get the current key
getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Returns the current key.
getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Returns the current key.
getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
 
getCurrentMode() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
getCurrentNrHRS() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
This method will be changed from public to package protected.
getCurrentPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
getCurrentPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.ReplicationSourceShipperThread
 
getCurrentPath() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
Get the current log that's replicated
getCurrentPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReaderThread
 
getCurrentPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
 
getCurrentPoolSize(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
 
getCurrentPosition() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
 
getCurrentPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.ReplicationSourceShipperThread
 
getCurrentSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Returns the occupied size of the block cache, in bytes.
getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
getCurrentSortField() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
getCurrentTerm() - Method in class org.apache.hadoop.hbase.util.LossyCounting
 
getCurrentTime() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
 
getCurrentUserName() - Method in class org.apache.hadoop.hbase.security.UserProvider
 
getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Returns the current value.
getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Returns the current value.
getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
 
getCursor() - Method in class org.apache.hadoop.hbase.client.Result
Return the cursor if this Result is a cursor result.
getCursor() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getCursorPosition() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
 
getCursorPosition() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
getCursorPosition() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
 
getCurTaskZKVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
 
getData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes data = 4;
getData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
optional bytes data = 4;
getData() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
optional bytes data = 4;
getData(String, Watcher, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getData is an idempotent operation.
getData(String, boolean, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
getData is an idemnpotent operation.
getData(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the current data in the unassigned node for the specified region name or fully-qualified path.
getData(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Get znode data.
getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
Deprecated.
 
getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
 
getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
 
getData(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Gets the data of the node.
getDataAndWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the current data in the unassigned node for the specified region name or fully-qualified path.
getDataAndWatch(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the data at the specified znode and set a watch.
getDataAndWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the data at the specified znode and set a watch.
getDataBlockCount() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Returns the number of data blocks currently cached in the block cache.
getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
getDataBlockEncoder() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getDataBlockEncoder() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getDataBlockEncoderById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Find and create data block encoder for given id;
getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
 
getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
 
getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
getDataBlockEncodingId() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getDataBlockEncodingOnDisk() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.98 (HBASE-9870). This will be removed in HBase 2.0.0. See HColumnDescriptor.getDataBlockEncoding()}
getDataBlockIndexReader() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getDataBlockIndexReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getDataChecksumType() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
Function to get corresponding DataChecksum.Type.
getDataCount() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
 
getDataHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getDataHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getDataHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getDataIndexCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getDataInMemoryWithoutWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getDataInMemoryWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Ammount of data in the memstore but not in the WAL because mutations explicitly had their WAL turned off.
getDataInMemoryWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getDataLocality() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getDataMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getDataMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getDataMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getDataNoWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the current data in the unassigned node for the specified region name or fully-qualified path.
getDataNoWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the data at the specified znode without setting a watch.
getDataSetWatchAsync() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
 
getDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
 
getDataSize() - Method in class org.apache.hadoop.hbase.util.LossyCounting
 
getDataToWriteToZooKeeper(Map<String, Integer>) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
Creates the labels data to be written to zookeeper.
getDataWriter() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
Get a writable interface into bloom filter data (the actual Bloom bits).
getDataWriter() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
getDataWriter() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
 
getDate() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
The date that hbase was compiled.
getDateTieredCompactionWindowFactory() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getDateTieredIncomingWindowMin() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getDateTieredMaxStoreFileAgeMillis() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getDaughterRegions(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getDaughterRegions(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the daughter regions by reading the corresponding columns of the catalog table Result.
getDeadline(RPCProtos.RequestHeader, Message) - Method in interface org.apache.hadoop.hbase.ipc.PriorityFunction
Returns the deadline of the specified request.
getDeadline() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
Return the deadline of this call.
getDeadline() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
getDeadline(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
Based on the request content, returns the deadline of the request.
getDeadline(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
getDeadNode(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
getDeadNodes() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
getDeadNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated string deadNodes = 2;
getDeadNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
repeated string deadNodes = 2;
getDeadNodes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
repeated string deadNodes = 2;
getDeadNodesBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated string deadNodes = 2;
getDeadNodesBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
repeated string deadNodes = 2;
getDeadNodesBytes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
repeated string deadNodes = 2;
getDeadNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated string deadNodes = 2;
getDeadNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
repeated string deadNodes = 2;
getDeadNodesCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
repeated string deadNodes = 2;
getDeadNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated string deadNodes = 2;
getDeadNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
repeated string deadNodes = 2;
getDeadNodesList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
repeated string deadNodes = 2;
getDeadRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get the dead region servers
getDeadRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getDeadRegionServers() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
 
getDeadServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getDeadServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getDeadServers() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
 
getDeadServers(long) - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
Get the servers which died since a given timestamp.
getDeadServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
 
getDeadServers() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getDeadServers__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getDecodabet(int) - Static method in class org.apache.hadoop.hbase.util.Base64
Returns one of the _SOMETHING_DECODABET byte arrays depending on the options specified.
getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodec
 
getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodecWithTags
 
getDecoder(InputStream) - Method in interface org.apache.hadoop.hbase.codec.Codec
 
getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec
Implementation depends on InputStream.available()
getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
Implementation depends on InputStream.available()
getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.MessageCodec
 
getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
 
getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
 
getDecompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Return a decryptor for decrypting data.
getDefaultBlockSize(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Return the number of bytes that large input files should be optimally be split into to minimize i/o time.
getDefaultBufferSize(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Returns the default buffer size to use during writes.
getDefaultChecksumType() - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
 
getDefaultCodec(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
getDefaultDetails() - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
 
getDefaultDetails() - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
 
getDefaultDetails() - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
 
getDefaultDetails() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
 
getDefaultExecutor(Configuration) - Static method in class org.apache.hadoop.hbase.client.HTable
 
getDefaultHost(String, String) - Static method in class org.apache.hadoop.hbase.util.DNS
Wrapper around DNS.getDefaultHost(String, String), calling DNS.getDefaultHost(String, String, boolean) when available.
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
getDefaultLength() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldInfo
 
getDefaultLoadBalancerClass() - Static method in class org.apache.hadoop.hbase.master.balancer.LoadBalancerFactory
The default LoadBalancer class.
getDefaultRegionLocation() - Method in class org.apache.hadoop.hbase.RegionLocations
 
getDefaultReplication(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getDefaultSortField() - Method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
 
getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy
 
getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
 
getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
 
getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy
 
getDefaultValues() - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getDelay(TimeUnit) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
getDelegate() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
Retrieves the singleton instance of the EnvironmentEdge that is being managed.
getDelegatesForTesting() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
Exposed for TESTING!
getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
 
getDeletableFiles(Iterable<FileStatus>) - Method in interface org.apache.hadoop.hbase.master.cleaner.FileCleanerDelegate
Determines which of the given files are safe to delete
getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
 
getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
 
getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
 
getDeleteBloomFilterMetadata() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
Retrieves delete family Bloom filter metadata as appropriate for each HFile version.
getDeleteBloomFilterMetadata() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
getDeleteFamilyBloomHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getDeleteFamilyBloomHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getDeleteFamilyBloomHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getDeleteFamilyBloomMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getDeleteFamilyBloomMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getDeleteFamilyBloomMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getDeleteFamilyCnt() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
getDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .hbase.pb.BulkDeleteRequest.DeleteType deleteType = 2;
getDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
required .hbase.pb.BulkDeleteRequest.DeleteType deleteType = 2;
getDeleteType() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
required .hbase.pb.BulkDeleteRequest.DeleteType deleteType = 2;
getDeleteType() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
getDelimiter(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
 
getDelimiterInReverse(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
Find index of passed delimiter walking from end of buffer backwards.
getDelta(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
getDependants() - Method in class org.apache.hadoop.hbase.generated.regionserver.region_jsp
 
getDependants() - Method in class org.apache.hadoop.hbase.generated.regionserver.regionserver_jsp
 
getDependants() - Method in class org.apache.hadoop.hbase.generated.regionserver.storeFile_jsp
 
getDependants() - Method in class org.apache.hadoop.hbase.generated.rest.rest_jsp
 
getDependants() - Method in class org.apache.hadoop.hbase.generated.thrift.thrift_jsp
 
getDesc(List<Throwable>, List<? extends Row>, List<String>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getDesc(Map<String, Integer>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getDescription() - Method in enum org.apache.hadoop.hbase.hbtop.field.Field
 
getDescription() - Method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
 
getDescription() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription
 
getDescription() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
 
getDescription() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
getDeserialiserIdentifier() - Method in interface org.apache.hadoop.hbase.io.hfile.CacheableDeserializer
Get the identifier of this deserialiser.
getDeserialiserMap() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getDeserializer() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
Returns CacheableDeserializer instance which reconstructs original object from ByteBuffer.
getDeserializer(int) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
Get the cacheable deserializer as the given identifier Id
getDeserializer() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getDeserializer(Class<KeyValue>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
 
getDeserializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
 
getDeserializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
getDestination() - Method in class org.apache.hadoop.hbase.master.RegionPlan
Get the destination server for the plan for this region.
getDetails() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Returns the configuration that was provided previously
getDetails() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
getDetailsForNonCoordinatedOpening() - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
Get details object with params for case when we're opening on regionserver side with all "default" properties.
getDetailsForNonCoordinatedOpening() - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
No ZK tracking will be performed for that case.
getDetaultDetails() - Method in interface org.apache.hadoop.hbase.coordination.CloseRegionCoordination
Get details object with params for case when we're closing on regionserver side internally (not because of RPC call from master), so we don't parse details from protobuf request.
getDetaultDetails() - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination
No ZK tracking will be performed for that case.
getDeterministicRandomSeed(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
Creates a deterministic hash code for store file collection.
getDeviation() - Method in class org.apache.hadoop.hbase.util.RollingStatCalculator
 
getDFSReplication() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getDifference() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
get/set
getDirectMemorySize() - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
 
getDirectMemoryUsage() - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
 
getDisabledOrDisablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Gets a list of all the tables set as disabled in zookeeper.
getDisabledTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Gets a list of all the tables set as disabled in zookeeper.
getDispersionInformation() - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
 
getDrainingServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
 
getDropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
getDumpServlet() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getDumpServlet() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getDurability() - Method in class org.apache.hadoop.hbase.client.Mutation
Get the current durability
getDurability() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns the durability setting for the table.
getDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
getDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
getDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
getDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
getEarliestFlushTimeForAllStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getEarliestFlushTimeForAllStores() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getEarliestMemstoreSeqNum(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
getEarliestMemstoreSeqNum(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
getEarliestMemstoreSeqNum(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
Deprecated.
Since version 1.2.0. Removing because not used and exposes subtle internal workings. Use WAL.getEarliestMemstoreSeqNum(byte[], byte[])
getEarliestMemstoreSeqNum(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
Gets the earliest unflushed sequence id in the memstore for the store.
getEdit() - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
Gets the edit
getEffectiveDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
getEffectiveDurability(Durability) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Returns effective durability from the passed durability and the table descriptor.
getEffectiveEncodingInCache(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
 
getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
getEffectiveUser() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
Get the current thread local effective user
getElements() - Method in class org.apache.hadoop.hbase.util.LossyCounting
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.append
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.atomicIncrement
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.checkAndPut
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.compact
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.createTable
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAll
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllRow
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllRowTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteTable
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.disableTable
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.enableTable
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.get
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getColumnDescriptors
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRegionInfo
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRow
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowOrBefore
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRows
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsWithColumns
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsWithColumnsTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowWithColumns
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowWithColumnsTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getTableNames
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getTableRegions
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getVer
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getVerTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.increment
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.incrementRows
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.isTableEnabled
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.majorCompact
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRow
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRows
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRowsTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRowTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerClose
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerGet
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerGetList
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpen
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithPrefix
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithScan
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithStop
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithStopTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.append
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.atomicIncrement
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.checkAndPut
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.compact
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.createTable
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAll
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRow
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRowTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteTable
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.disableTable
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.enableTable
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.get
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getColumnDescriptors
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRegionInfo
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRow
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowOrBefore
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRows
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumns
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumnsTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumns
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumnsTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableNames
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableRegions
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVer
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVerTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.increment
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.incrementRows
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.isTableEnabled
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.majorCompact
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRow
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRows
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowsTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerClose
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGet
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGetList
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpen
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithPrefix
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithScan
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStop
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStopTs
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.append
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndDelete
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndMutate
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndPut
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.closeScanner
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.deleteMultiple
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.deleteSingle
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.exists
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.get
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getAllRegionLocations
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getMultiple
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getRegionLocation
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getScannerResults
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getScannerRows
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.increment
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.mutateRow
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.openScanner
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.put
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.putMultiple
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.append
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndDelete
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndMutate
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndPut
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.closeScanner
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteMultiple
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteSingle
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.exists
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.existsAll
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.get
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getAllRegionLocations
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getMultiple
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getRegionLocation
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerResults
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerRows
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.increment
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.mutateRow
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.openScanner
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.put
 
getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.putMultiple
 
getEnabled() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
 
getEnablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Gets a list of all the tables set as enabling in zookeeper.
getEncodedCompressedSize(Compression.Algorithm, Compressor) - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
Estimate size after second stage of compression (e.g.
getEncodedName() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getEncodedNameAsBytes() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getEncodedNodeName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
Gets the full path node name for the log file being split.
getEncodedPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getEncodedRegionName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the region's encoded name.
getEncodedRegionName() - Method in class org.apache.hadoop.hbase.wal.WALKey
 
getEncodedRegionName() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer
 
getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodec
 
getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodecWithTags
 
getEncoder(OutputStream) - Method in interface org.apache.hadoop.hbase.codec.Codec
 
getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec
 
getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
 
getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.MessageCodec
 
getEncoder() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Return new data block encoder for given algorithm type.
getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
 
getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
 
getEncodingById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
getEncodingCountsForTest() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
getEncodingState() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
getEncodingState() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
 
getEncryptionContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
getEncryptionKey() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Return the raw crypto key attribute for the family, or null if not set
getEncryptionKey() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getEncryptionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Return the encryption algorithm in use by this family
getEncryptor() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
getEncryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Get an encryptor for encrypting data.
getEnd() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
 
getEnd() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
getEndKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getEndKey() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
 
getEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional bytes endKey = 3;
getEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
optional bytes endKey = 3;
getEndKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
optional bytes endKey = 3;
getEndKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
getEndKey() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
getEndKey() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
getEndKey() - Method in interface org.apache.hadoop.hbase.util.KeyRange
 
getEndKeys() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
Gets the ending row key for every region in the currently open table.
getEndKeys() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
Since 1.1.0. Use RegionLocator.getEndKeys() instead;
getEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Gets the ending row key for every region in the currently open table.
getEndRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getEndRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the end row.
getEndRow(int) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
Gets the end row for a given stripe.
getEndRow(int) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getEndRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
getEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bytes endRow = 2;
getEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional bytes endRow = 2;
getEndRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional bytes endRow = 2;
getEndRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
getEndTime() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
getEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int64 endTime = 6;
getEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int64 endTime = 6;
getEndTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int64 endTime = 6;
getEndTime() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
getEntries() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
 
getEntries() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getEntries() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getEntries() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getEntries() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
 
getEntry(short) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
Gets an entry from the dictionary.
getEntry(short) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
 
getEntryBuffer() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer
 
getEntryCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getEnvironment() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
 
getEnvironment() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
getErr() - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
 
getErrorHandler() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
getErrorHandler() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
 
getErrorList() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
getErrorMonitor() - Method in class org.apache.hadoop.hbase.procedure.Procedure
Get the ForeignExceptionDispatcher
getErrorRate(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
 
getErrors() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
getEstimatedNumberOfKvsScanned() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
getEventType() - Method in class org.apache.hadoop.hbase.executor.EventHandler
Return the event type
getEventType() - Method in class org.apache.hadoop.hbase.RegionTransition
 
getEvictCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getException(byte[]) - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
getException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
 
getException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
Get the value of the captured exception.
getException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
getException() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
getException() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getException() - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
Get the last exception which has occurred when re-setting the watch.
getExceptionCause() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getExceptionFullMessage() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
 
getExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
 
getExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
getExceptionIfFailed() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
Get the exception that caused the snapshot to fail, if the snapshot has failed.
getExceptionMessage() - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
getExceptionMessage() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getExceptionMessageAdditionalDetail() - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
 
getExceptionMsg() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
 
getExceptions() - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
getExcludedServersForSystemTable() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Get a list of servers that this region can not assign to.
getExecutor() - Method in class org.apache.hadoop.metrics2.lib.MetricsExecutorImpl
 
getExecutor() - Method in interface org.apache.hadoop.metrics2.MetricsExecutor
 
getExecutorService() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getExecutorService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getExecutorService() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getExecutorThreadPool(ExecutorType) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
 
getExhaustiveDescription() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getExist() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
getExistingAssignmentPlan() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
Get the favored nodes plan
getExistingLabelsWithAuths() - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
getExists() - Method in class org.apache.hadoop.hbase.client.Result
 
getExistsResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
 
getExpectedVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
 
getExpiration() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
 
getExpirationDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getExpression() - Method in class org.apache.hadoop.hbase.security.visibility.CellVisibility
 
getExpression() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
getExtraHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Get an extra header value.
getExtraHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Client
Get all extra headers (read-only).
getFailed() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
getFailed() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
Return the failed exception, null if not failed.
getFailed() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
getFailedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getFailedDeletions() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
 
getFailedFiles() - Method in exception org.apache.hadoop.hbase.backup.FailedArchiveException
 
getFailedIncrements() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getFailedIncrements() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getFailedInserts() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getFailedInserts() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getFailedOn() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
Returns any exception thrown during service method invocation, or null if no exception was thrown.
getFailedOpenTracker() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
getFailureCount() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
getFailures() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
 
getFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
 
getFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns an unmodifiable collection of all the HColumnDescriptor of all the column families of the table.
getFamilies() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
 
getFamiliesKeys() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns all the column family names of the current table.
getFamily() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
getFamily() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getFamily() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
getFamily() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns the HColumnDescriptor for a specific column family with name as specified by the parameter column.
getFamily() - Method in class org.apache.hadoop.hbase.KeyValue
Deprecated.
getFamily(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
getFamily() - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the column family used for meta columns.
getFamily() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getFamily() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
 
getFamily() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getFamily() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
getFamily() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
getFamily() - Method in class org.apache.hadoop.hbase.TagRewriteCell
Deprecated.
getFamily() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
column name
getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
column family to check
getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
column family to check
getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
column family to check
getFamilyArray() - Method in interface org.apache.hadoop.hbase.Cell
Contiguous bytes composed of legal HDFS filename characters which may start at any index in the containing array.
getFamilyArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getFamilyArray() - Method in class org.apache.hadoop.hbase.KeyValue
 
getFamilyArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getFamilyArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getFamilyCellMap() - Method in class org.apache.hadoop.hbase.client.Mutation
Method for retrieving the put's familyMap
getFamilyDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Given a particular region dir, return all the familydirs inside it
getFamilyLength() - Method in interface org.apache.hadoop.hbase.Cell
 
getFamilyLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getFamilyLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getFamilyLength(int) - Method in class org.apache.hadoop.hbase.KeyValue
 
getFamilyLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getFamilyLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's familyMap
getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
getFamilyMap(byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Map of qualifiers to values.
getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Scan
Getting the familyMap
getFamilyMapOfLongs() - Method in class org.apache.hadoop.hbase.client.Increment
Before 0.95, when you called Increment#getFamilyMap(), you got back a map of families to a list of Longs.
getFamilyOffset() - Method in interface org.apache.hadoop.hbase.Cell
 
getFamilyOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getFamilyOffset(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getFamilyOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getFamilyOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getFamilyOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getFamilyOffsetWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getFamilySorter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getFamilyString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
getFamilyWriter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getFanByte(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getFanByteReadable(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
for debugging
getFanIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getFanOut() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getFavoredNodeList(String) - Static method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
 
getFavoredNodes(List<ServerName>) - Static method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
 
getFavoredNodes(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
 
getFavoredNodes(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
 
getFavoredNodesAsString(List<ServerName>) - Static method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
 
getFavoredNodesForRegion(String) - Method in interface org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion
Get the favored nodes mapping for this region.
getFavoredNodesForRegion(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Return the favored nodes for a region given its encoded name.
getFavoredNodesList(byte[]) - Static method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
 
getFavoredServerPosition(List<ServerName>, ServerName) - Static method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
Return the position of the server in the favoredNodes list.
getField() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldInfo
 
getField() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Header
 
getFieldDesc(TMutation._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
getFieldInfos() - Method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
 
getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy
 
getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
 
getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
 
getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy
 
getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TAppend._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TAppend._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TAuthorization._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TCellVisibility._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionInfo._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionLocation._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TServerName._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
 
getFields() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
getFieldValue(AlreadyExists._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
getFieldValue(BatchMutation._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
getFieldValue(ColumnDescriptor._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
getFieldValue(Hbase.append_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
getFieldValue(Hbase.append_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
getFieldValue(Hbase.atomicIncrement_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
getFieldValue(Hbase.atomicIncrement_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
getFieldValue(Hbase.checkAndPut_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
getFieldValue(Hbase.checkAndPut_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
getFieldValue(Hbase.compact_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
getFieldValue(Hbase.compact_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
getFieldValue(Hbase.createTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
getFieldValue(Hbase.createTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
getFieldValue(Hbase.deleteAll_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
getFieldValue(Hbase.deleteAll_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
getFieldValue(Hbase.deleteAllRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
getFieldValue(Hbase.deleteAllRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
getFieldValue(Hbase.deleteAllRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
getFieldValue(Hbase.deleteAllRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
getFieldValue(Hbase.deleteAllTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
getFieldValue(Hbase.deleteAllTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
getFieldValue(Hbase.deleteTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
getFieldValue(Hbase.deleteTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
getFieldValue(Hbase.disableTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
getFieldValue(Hbase.disableTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
getFieldValue(Hbase.enableTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
getFieldValue(Hbase.enableTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
getFieldValue(Hbase.get_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
getFieldValue(Hbase.get_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
getFieldValue(Hbase.getColumnDescriptors_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
getFieldValue(Hbase.getColumnDescriptors_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
getFieldValue(Hbase.getRegionInfo_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
getFieldValue(Hbase.getRegionInfo_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
getFieldValue(Hbase.getRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
getFieldValue(Hbase.getRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
getFieldValue(Hbase.getRowOrBefore_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
getFieldValue(Hbase.getRowOrBefore_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
getFieldValue(Hbase.getRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
getFieldValue(Hbase.getRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
getFieldValue(Hbase.getRowsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
getFieldValue(Hbase.getRowsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
getFieldValue(Hbase.getRowsWithColumns_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
getFieldValue(Hbase.getRowsWithColumns_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
getFieldValue(Hbase.getRowsWithColumnsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
getFieldValue(Hbase.getRowsWithColumnsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
getFieldValue(Hbase.getRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
getFieldValue(Hbase.getRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
getFieldValue(Hbase.getRowWithColumns_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
getFieldValue(Hbase.getRowWithColumns_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
getFieldValue(Hbase.getRowWithColumnsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
getFieldValue(Hbase.getRowWithColumnsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
getFieldValue(Hbase.getTableNames_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
getFieldValue(Hbase.getTableNames_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
getFieldValue(Hbase.getTableRegions_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
getFieldValue(Hbase.getTableRegions_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
getFieldValue(Hbase.getVer_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
getFieldValue(Hbase.getVer_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
getFieldValue(Hbase.getVerTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
getFieldValue(Hbase.getVerTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
getFieldValue(Hbase.increment_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
getFieldValue(Hbase.increment_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
getFieldValue(Hbase.incrementRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
getFieldValue(Hbase.incrementRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
getFieldValue(Hbase.isTableEnabled_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
getFieldValue(Hbase.isTableEnabled_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
getFieldValue(Hbase.majorCompact_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
getFieldValue(Hbase.majorCompact_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
getFieldValue(Hbase.mutateRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
getFieldValue(Hbase.mutateRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
getFieldValue(Hbase.mutateRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
getFieldValue(Hbase.mutateRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
getFieldValue(Hbase.mutateRowsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
getFieldValue(Hbase.mutateRowsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
getFieldValue(Hbase.mutateRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
getFieldValue(Hbase.mutateRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
getFieldValue(Hbase.scannerClose_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
getFieldValue(Hbase.scannerClose_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
getFieldValue(Hbase.scannerGet_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
getFieldValue(Hbase.scannerGet_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
getFieldValue(Hbase.scannerGetList_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
getFieldValue(Hbase.scannerGetList_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
getFieldValue(Hbase.scannerOpen_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
getFieldValue(Hbase.scannerOpen_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
getFieldValue(Hbase.scannerOpenTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
getFieldValue(Hbase.scannerOpenTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
getFieldValue(Hbase.scannerOpenWithPrefix_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
getFieldValue(Hbase.scannerOpenWithPrefix_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
getFieldValue(Hbase.scannerOpenWithScan_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
getFieldValue(Hbase.scannerOpenWithScan_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
getFieldValue(Hbase.scannerOpenWithStop_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
getFieldValue(Hbase.scannerOpenWithStop_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
getFieldValue(Hbase.scannerOpenWithStopTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
getFieldValue(Hbase.scannerOpenWithStopTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
getFieldValue(IllegalArgument._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
getFieldValue(IOError._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
getFieldValue(Mutation._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
getFieldValue(TAppend._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
getFieldValue(TCell._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
getFieldValue(TColumn._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
getFieldValue(TIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
getFieldValue(TRegionInfo._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
getFieldValue(TRowResult._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
getFieldValue(TScan._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
getFieldValue(TAppend._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
getFieldValue(TAuthorization._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
getFieldValue(TCellVisibility._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
getFieldValue(TColumn._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
getFieldValue(TColumnIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
getFieldValue(TColumnValue._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
getFieldValue(TDelete._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
getFieldValue(TGet._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getFieldValue(THBaseService.append_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
getFieldValue(THBaseService.append_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
getFieldValue(THBaseService.checkAndDelete_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
getFieldValue(THBaseService.checkAndDelete_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
getFieldValue(THBaseService.checkAndMutate_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
getFieldValue(THBaseService.checkAndMutate_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
getFieldValue(THBaseService.checkAndPut_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
getFieldValue(THBaseService.checkAndPut_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
getFieldValue(THBaseService.closeScanner_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
getFieldValue(THBaseService.closeScanner_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
getFieldValue(THBaseService.deleteMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
getFieldValue(THBaseService.deleteMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
getFieldValue(THBaseService.deleteSingle_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
getFieldValue(THBaseService.deleteSingle_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
getFieldValue(THBaseService.exists_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
getFieldValue(THBaseService.exists_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
getFieldValue(THBaseService.existsAll_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
getFieldValue(THBaseService.existsAll_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
getFieldValue(THBaseService.get_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
getFieldValue(THBaseService.get_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
getFieldValue(THBaseService.getAllRegionLocations_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
getFieldValue(THBaseService.getAllRegionLocations_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
getFieldValue(THBaseService.getMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
getFieldValue(THBaseService.getMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
getFieldValue(THBaseService.getRegionLocation_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
getFieldValue(THBaseService.getRegionLocation_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
getFieldValue(THBaseService.getScannerResults_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
getFieldValue(THBaseService.getScannerResults_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
getFieldValue(THBaseService.getScannerRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
getFieldValue(THBaseService.getScannerRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
getFieldValue(THBaseService.increment_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
getFieldValue(THBaseService.increment_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
getFieldValue(THBaseService.mutateRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
getFieldValue(THBaseService.mutateRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
getFieldValue(THBaseService.openScanner_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
getFieldValue(THBaseService.openScanner_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
getFieldValue(THBaseService.put_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
getFieldValue(THBaseService.put_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
getFieldValue(THBaseService.putMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
getFieldValue(THBaseService.putMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
getFieldValue(THRegionInfo._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
getFieldValue(THRegionLocation._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
getFieldValue(TIllegalArgument._Fields) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
getFieldValue(TIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
getFieldValue(TIOError._Fields) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
getFieldValue(TPut._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
getFieldValue(TResult._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
getFieldValue(TRowMutations._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
getFieldValue(TScan._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getFieldValue(TServerName._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
getFieldValue(TTimeRange._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
getFieldValueType() - Method in enum org.apache.hadoop.hbase.hbtop.field.Field
 
getFifteenMinuteRate() - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
 
getFifteenMinuteRate() - Method in interface org.apache.hadoop.hbase.metrics.Meter
Returns the fifteen-minute exponentially-weighted moving average rate at which events have occurred since the meter was created.
getFileCacheForTesting() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
Exposed for Testing!
getFileContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
Return the file context of the HFile this reader belongs to
getFileContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
Return the file context for the HFile this writer belongs to
getFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
getFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
 
getFileCreateTime() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
getFileDetails(Collection<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
Extracts some details about the files to compact that are commonly needed by compactors.
getFileInfo() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getFileInfoHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getFileInfoHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getFileInfoHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getFileInfoMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getFileInfoMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getFileInfoMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getFileInfoOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getFileLinkWithPreNSPath(Path) - Method in class org.apache.hadoop.hbase.util.HFileV1Detector
Creates a FileLink which adds pre-namespace paths in its list of available paths.
getFileList(Configuration, List<Path>, PathFilter) - Static method in class org.apache.hadoop.hbase.master.SplitLogManager
Get a list of paths that need to be split given a set of server-specific directories and optionally a filter.
getFilename() - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
 
getFilename() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
 
getFileName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
getFilenum() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
getFileNumFromFileName(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
A log file has a creation timestamp (in ms) in its file name (FSHLog.filenum.
getFilePermissions(FileSystem, Configuration, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Get the file permissions specified in the configuration, if they are enabled.
getFileRegion() - Method in class org.apache.hadoop.hbase.io.Reference
 
getFiles() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
getFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
Get the backing files associated with this WAL.
getFilesForScanOrGet(byte[], boolean, byte[], boolean) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Gets the store files to scan for a Scan or Get request.
getFilesForScanOrGet(byte[], boolean, byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getFileStatus(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
Get the FileStatus of the referenced file.
getFileStatus() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
getFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
getFileSystem() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
getFilesystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
 
getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getFileSystem() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getFileSystem() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getFilesystem() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
getFileSystem() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
 
getFilter() - Method in class org.apache.hadoop.hbase.client.Query
 
getFilter() - Method in class org.apache.hadoop.hbase.client.Scan
 
getFilter() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
getFilter() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
getFilter() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
getFilter() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.LegacyScanQueryMatcher
Deprecated.
 
getFilter() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
getFilter() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
getFilter() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
getFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional string filter = 8;
getFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional string filter = 8;
getFilter() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional string filter = 8;
getFilter() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
 
getFilter() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getFilter() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
getFilter__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
 
getFilter__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getFilter__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
getFilterArguments(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns the arguments of the filter from the filter string
getFilterBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional string filter = 8;
getFilterBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional string filter = 8;
getFilterBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional string filter = 8;
getFilterEntries() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
 
getFilterEntries() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
The number of Bloom filter entries in this store file, or an estimate thereof, if the Bloom filter is not loaded.
getFilterHistories() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
getFilterIfMissing() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Get whether entire row should be filtered if column is not found.
getFilterName(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns the filter name given a simple filter expression
getFilterParams(Configuration, String) - Static method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
Constructs a mapping of configuration properties to be used for filter initialization.
getFilters() - Method in class org.apache.hadoop.hbase.filter.FilterList
Get the filters.
getFilters() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
getFilters() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
getFilterString() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
getFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getFingerprint() - Method in class org.apache.hadoop.hbase.client.Get
Compile the table and column family (i.e.
getFingerprint() - Method in class org.apache.hadoop.hbase.client.Mutation
Compile the column family (i.e.
getFingerprint() - Method in class org.apache.hadoop.hbase.client.Operation
Produces a Map containing a fingerprint which identifies the type and the static schema components of a query (i.e.
getFingerprint() - Method in class org.apache.hadoop.hbase.client.Scan
Compile the table and column family (i.e.
getFirst(long[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
 
getFirst(Collection<T>) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
first/last
getFirst() - Method in class org.apache.hadoop.hbase.util.Pair
Return the first element stored in the pair.
getFirst() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
Return the first element stored in the pair.
getFirst() - Method in class org.apache.hadoop.hbase.util.Triple
 
getFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getFirstFailureAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
getFirstInsertionIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getFirstKey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
 
getFirstKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getFirstKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getFirstKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getFirstKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
Deprecated.
 
getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
getFirstKeyInBlock(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Return first key in block.
getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
 
getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
 
getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
 
getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
 
getFirstKeyInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
getFirstKeyInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
getFirstKeyInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
getFirstRowKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
TODO left from HFile version 1: move this to StoreFile after Ryan's patch goes in to eliminate KeyValue here.
getFirstRowKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getFiveMinuteRate() - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
 
getFiveMinuteRate() - Method in interface org.apache.hadoop.hbase.metrics.Meter
Returns the five-minute exponentially-weighted moving average rate at which events have occurred since the meter was created.
getFlushableSize() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
 
getFlushableSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getFlushableSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
On flush, how much memory we will clear.
getFlushableSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getFlushDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
getFlushedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getFlushedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of cells flushed to disk.
getFlushedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getFlushedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getFlushedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the total amount of data flushed to disk, in bytes.
getFlushedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getFlushedOutputFileSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getFlushedOutputFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getFlushPolicyClass(HTableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
Get FlushPolicy class for the given table.
getFlushPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
This gets the class associated with the flush policy which determines the stores need to be flushed when flushing a region.
getFlushPressure() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getFlushPressure() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getFlushQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the size of the flush queue.
getFlushRequester() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getFlushRequester() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getFlushThroughputController() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getFlushThroughputController() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getForegroundColor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
getForegroundColor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
getForeignExceptionMessage() - Method in class org.apache.hadoop.hbase.ProcedureInfo
Deprecated.
getFormat() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
 
getFormat() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getFormat() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
getFormat__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
 
getFormat__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getFormat__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
getFormatVersion(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
getFrags() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getFrags__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getFreeBytes() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
getFreeMemory() - Method in class org.apache.hadoop.hbase.util.JVM
 
getFreeSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Returns the free size of the block cache, in bytes.
getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
getFromOnlineRegions(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getFromOnlineRegions(String) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
Return Region instance.
getFromThrift(TGet) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
Creates a Get (HBase) from a TGet (Thrift).
getFs() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Get the handle on the local file system
getGauge(String, long) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Get a MetricMutableGaugeLong from the storage.
getGeneralBloomFilterMetadata() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
Retrieves general Bloom filter metadata as appropriate for each HFile version.
getGeneralBloomFilterMetadata() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
Returns a buffer with the Bloom filter metadata.
getGeneralBloomMetaHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getGeneralBloomMetaHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getGeneralBloomMetaHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getGeneralBloomMetaMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getGeneralBloomMetaMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getGeneralBloomMetaMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
getGeneralQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Retrieves length of the general queue for metrics.
getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
getGlobalLimiter() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
Return the limiter associated with this quota.
getGlobalMemStoreLowerMark(Configuration, float) - Static method in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
Retrieve configured size for global memstore lower water mark as fraction of global memstore size.
getGlobalMemStorePercent(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
Retrieve global memstore configured size as percentage of total heap.
getGlobalMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
 
getGlobalSource() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactory
 
getGlobalSource() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl
 
getGroupAuths(String[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
getGroupAuths(String[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
 
getGroupAuths(String[], boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
Retrieve the visibility labels for the groups.
getGroupAuthsAsOrdinals(String[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
Returns the list of ordinals of labels associated with the groups
getGroupInfoManager() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
getGroupName(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
Returns the actual name for a group principal (stripped of the group prefix).
getGroupNames() - Method in class org.apache.hadoop.hbase.security.User
Returns the list of groups of which this user is a member.
getGroupNames() - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
 
getHandler(String, double, BlockingQueue<CallRunner>, AtomicInteger) - Method in class org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutor
 
getHandler(String, double, BlockingQueue<CallRunner>, AtomicInteger) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
Override if providing alternate Handler implementation.
getHashCount() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
getHashType() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
getHashType(Configuration) - Static method in class org.apache.hadoop.hbase.util.Hash
This utility method converts the name of the configured hash type to a symbolic constant.
getHBaseServerWrapper() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
 
getHBaseVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getHBaseVersion() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
 
getHBaseVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getHDFSBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getHDFSBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
getHDFSBlocksDistribution() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getHDFSBlocksDistribution() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getHead() - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
 
getHeader() - Method in enum org.apache.hadoop.hbase.hbtop.field.Field
 
getHeader() - Method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
 
getHeader() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
getHeader() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
getHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Response
 
getHeader(String) - Method in interface org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.HttpInteraction
Returns the value of a header.
getHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Response
 
getHeadPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the head of the linked list (least recently used).
getHeap() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
getHeapMemoryManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getHeapMemoryManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getHeapOccupancyPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
getHeapOccupancyPercent() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
getHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
getHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int32 heapSizeMB = 4;
getHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
optional int32 heapSizeMB = 4;
getHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
optional int32 heapSizeMB = 4;
getHFileBlock() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
 
getHFileCleaner() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getHFileContext() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockDecodingContext
 
getHFileContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
 
getHFileContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
getHFileContext() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
 
getHFilecorruptionChecker() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
getHFileFromBackReference(Path, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Get the full path of the HFile referenced by the back reference
getHFileFromBackReference(Configuration, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Get the full path of the HFile referenced by the back reference
getHFileMinorVersion() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getHfileName() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
getHFileName() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
getHFileNames(Configuration, FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Returns the store file names in the snapshot.
getHFileReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getHFileRefsNodeChangeVersion() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get the change version number of replication hfile references node.
getHFileRefsNodeChangeVersion() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getHFilesChecked() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
 
getHFileVersion() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getHfs() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
 
getHistogram() - Method in class org.apache.hadoop.hbase.metrics.impl.TimerImpl
 
getHistogram() - Method in interface org.apache.hadoop.hbase.metrics.Timer
 
getHistogram(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
 
getHistogramReport(Histogram) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
 
getHitCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getHitCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getHitCachingRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getHitCachingRatioPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getHitCount() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the number of hits to the map.
getHitRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getHitRatio() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the hit ratio.
getHitRatioPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getHost() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
 
getHostAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
getHostAndPort() - Method in class org.apache.hadoop.hbase.ServerName
 
getHostAndWeights() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
 
getHostInetAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
getHostname() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getHostname() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getHostname() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
getHostname() - Method in class org.apache.hadoop.hbase.net.Address
 
getHostname(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
getHostname() - Method in class org.apache.hadoop.hbase.ServerName
 
getHostName() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
getHostnamePort(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getHostnamePort() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getHRegion() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getHRegionInfo(Result, byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getHRegionInfo() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
 
getHRegionInfo() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
 
getHRegionInfo() - Method in interface org.apache.hadoop.hbase.master.handler.TotesHRegionInfo
 
getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns HRegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result.
getHRegionInfoAndServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getHris() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
 
getHTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
getHTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
getHTableDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getHTableDescriptor(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getHTableDescriptorArray(MasterProtos.GetTableDescriptorsResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Get HTableDescriptor[] from GetTableDescriptorsResponse protobuf
getHTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getHTableDescriptorsByTableName(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getHTableMultiplexerStatus() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
 
getHtd() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
 
getHttpClient() - Method in class org.apache.hadoop.hbase.rest.client.Client
 
getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
getIa() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
if the scannerId is invalid
getIa() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
if the scannerId is invalid
getId() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
This method allows you to retrieve the identifier for the operation if one was set.
getId() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getId() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
getId() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
Use this instead of Enum.ordinal().
getId() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
 
getId() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
Get the identifier of this peer
getId() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Get the identifier of this peer
getId() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
 
getId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional int64 id = 4;
getId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
optional int64 id = 4;
getId() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
optional int64 id = 4;
getID() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
getId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
id of a scanner returned by scannerOpen
getId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
id of a scanner returned by scannerOpen
getId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
id of a scanner returned by scannerOpen
getId() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
getId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
getIdentifier(String, SecretManager<T>) - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
 
getIdentifier() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
 
getIdentifier() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
getIfCached(Path) - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
 
getImplData() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
 
getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
 
getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
 
getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
 
getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
 
getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
 
getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
 
getIncludesMvccVersionByte() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getIncrement() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
The single increment to apply
getIncrements() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
The list of increments
getIncrementsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
getIncrementsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
getIndex(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
getInfo(String) - Static method in class org.apache.hadoop.hbase.security.SecurityInfo
Returns the security configuration associated with the given service name.
getInformativeName() - Method in class org.apache.hadoop.hbase.executor.EventHandler
Event implementations should override thie class to provide an informative name about what event they are handling.
getInfoServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getInfoServerPort() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getInitialCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
 
getInitialDelay() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
getInitialFilters() - Method in class org.apache.hadoop.hbase.hbtop.mode.DrillDownInfo
 
getInitializedEvent() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getInitialResponse() - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
getInitialState() - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
Return the initial state object that will be used for the first call to executeFromState().
getInlineBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
 
getInlineBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
The type of blocks this block writer produces.
getInlineBlockType() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
 
getInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional bool inMemory = 4;
getInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
optional bool inMemory = 4;
getInMemory() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
optional bool inMemory = 4;
getInputStream() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
 
getInputStream() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
 
getInputStream(InputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
Get a SASL wrapped InputStream.
getInstance(Class<T>) - Static method in class org.apache.hadoop.hbase.CompatibilityFactory
 
getInstance(Class<T>) - Static method in class org.apache.hadoop.hbase.CompatibilitySingletonFactory
Get the singleton instance of Any classes defined by compatibiliy jar's
getInstance() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
 
getInstance() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getInstance() - Static method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
 
getInstance() - Static method in class org.apache.hadoop.hbase.master.normalizer.EmptyNormalizationPlan
 
getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
 
getInstance(int, int) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
 
getInstance() - Static method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
 
getInstance() - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
 
getInstance(Configuration, UserProvider) - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
 
getInstance() - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
 
getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.trace.SpanReceiverHost
 
getInstance(FileSystem, Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getInstance(int) - Static method in class org.apache.hadoop.hbase.util.Hash
Get a singleton instance of hash function of a given type.
getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.util.Hash
Get a singleton instance of hash function of a type defined in the configuration.
getInstance() - Static method in class org.apache.hadoop.hbase.util.JenkinsHash
 
getInstance() - Static method in class org.apache.hadoop.hbase.util.MurmurHash
 
getInstance() - Static method in class org.apache.hadoop.hbase.util.MurmurHash3
 
getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
 
getInt(Configuration, String, String, int) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Get the value of the name property as an int, possibly referring to the deprecated name of the configuration property.
getInt(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
getInt() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
getInt(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Retrieve the int value at index
getInt() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Retrieve the next int value from this range.
getInt(byte[]) - Static method in class org.apache.hadoop.hbase.util.vint.UVIntTool
bytes -> int
getInt(byte[], int) - Static method in class org.apache.hadoop.hbase.util.vint.UVIntTool
 
getInt(InputStream) - Static method in class org.apache.hadoop.hbase.util.vint.UVIntTool
 
getIntermediateIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getIntermediateIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getIntermediateIndexHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getIntermediateIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getIntermediateIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getIntermediateIndexMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
getIoEngine() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getIOHitsPerSecond() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
 
getIOTimePerHit() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
 
getIp4Address() - Static method in class org.apache.hadoop.hbase.util.Addressing
 
getIp6Address() - Static method in class org.apache.hadoop.hbase.util.Addressing
 
getIpAddress() - Static method in class org.apache.hadoop.hbase.util.Addressing
 
getIsActiveMaster() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Whether this master is the active master
getIsActiveMaster() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getIsolationLevel() - Method in class org.apache.hadoop.hbase.client.Query
 
getIssueDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getItemAllocationSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
getIterator(int) - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
Provides access to compressed value.
getIterator() - Method in class org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
 
getIv() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
 
getIv() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Get the initialization vector
getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
 
getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
 
getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Return the expected initialization vector length, in bytes, or 0 if not applicable
getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
Get the expected length for the initialization vector
getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Get the expected length for the initialization vector
getJar(Class) - Static method in class org.apache.hadoop.hbase.mapreduce.JarFinder
Returns the full path to the Jar containing the class.
GetJavaProperty - Class in org.apache.hadoop.hbase.util
A generic way for querying Java properties.
GetJavaProperty() - Constructor for class org.apache.hadoop.hbase.util.GetJavaProperty
 
getJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
 
getJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jerseyVersion = 5;
getJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string jerseyVersion = 5;
getJerseyVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string jerseyVersion = 5;
getJerseyVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jerseyVersion = 5;
getJerseyVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string jerseyVersion = 5;
getJerseyVersionBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string jerseyVersion = 5;
getJournal() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
Get the journal for the transaction.
getJournal() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
 
getJournal() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
Get the journal for the transaction.
getJournal() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
 
getJVMVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
 
getJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jvmVersion = 2;
getJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string jvmVersion = 2;
getJvmVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string jvmVersion = 2;
getJvmVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jvmVersion = 2;
getJvmVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string jvmVersion = 2;
getJvmVersionBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string jvmVersion = 2;
getKeepAliveMasterService() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Deprecated.
getKeepAliveMasterService() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Since 0.96.0
getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
 
getKey() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
getKey(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
Retrieve the key for a given key aliase
getKey(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
getKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
getKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
getKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Gets a buffer view to the current key.
getKey() - Method in class org.apache.hadoop.hbase.KeyValue
Do not use unless you have to.
getKey() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getKey() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Get the key of this entry.
getKey() - Method in class org.apache.hadoop.hbase.rest.model.RowModel
 
getKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
required bytes key = 1;
getKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
required bytes key = 1;
getKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
required bytes key = 1;
getKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
required string key = 1;
getKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
required string key = 1;
getKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.PropertyOrBuilder
required string key = 1;
getKey() - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
Gets the key
getKeyBytes() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
getKeyBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
required string key = 1;
getKeyBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
required string key = 1;
getKeyBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.PropertyOrBuilder
required string key = 1;
getKeyBytesHash() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
getKeyCount() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
 
getKeyCount() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
getKeyCount() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
 
getKeyDataStructureSize(int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
Computes the number of bytes that a KeyValue instance with the provided characteristics would take up in its underlying data structure for the key.
getKeyDeepCopy() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
getKeyDeepCopy() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
Does a deep copy of the key at the current position.
getKeyDeepCopy() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
getKeyFormat() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
getKeyForNextColumn(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
getKeyId() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
 
getKeyId() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getKeyLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
getKeyLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Return the key length required by this cipher, in bytes
getKeyLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getKeyLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getKeyOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getKeyOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getKeyProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
getKeys() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription
 
getKeys(String[]) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
Retrieve keys for a given set of key aliases
getKeys(String[]) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
getKeyString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
getKeyString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
getKeyString() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Convenience method to get a copy of the key as a string - interpreting the bytes as UTF8.
getKeyString() - Method in class org.apache.hadoop.hbase.KeyValue
 
getKeyValue() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
currently must do deep copy into new array
getKeyValue() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
 
getKeyValue() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
getKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
getKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
getKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
 
getKeyValue() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
getKeyValueCount(RpcController, ExampleProtos.CountRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.BlockingInterface
 
getKeyValueCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
rpc getKeyValueCount(.hbase.pb.CountRequest) returns (.hbase.pb.CountResponse);
getKeyValueCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.Interface
rpc getKeyValueCount(.hbase.pb.CountRequest) returns (.hbase.pb.CountResponse);
getKeyValueCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.Stub
 
getKeyValueCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
Returns a count of all KeyValues in the region where this coprocessor is loaded.
getKeyValueDataStructureSize(int, int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
Computes the number of bytes that a KeyValue instance with the provided characteristics would take up for its underlying data structure.
getKeyValueDataStructureSize(int, int, int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
Computes the number of bytes that a KeyValue instance with the provided characteristics would take up for its underlying data structure.
getKeyValueDataStructureSize(int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
Computes the number of bytes that a KeyValue instance with the provided characteristics would take up for its underlying data structure.
getKeyValues(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
Retrieve a list of key value pairs from configuration, stored under the provided key
getKeyValues(Configuration, String, char) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
Retrieve a list of key value pairs from configuration, stored under the provided key
getKeyValueString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
Need this separate method so we can call it from subclasses' toString() methods
getKeyValueTypeWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
methods
getKind() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getL1CacheHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Hit count of L1 cache.
getL1CacheHitRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Hit ratio of L1 cache.
getL1CacheMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Miss count of L1 cache.
getL1CacheMissRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Miss ratio of L1 cache.
getL1Stats() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
getL2BlockCacheHeapPercent(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
 
getL2CacheHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Hit count of L2 cache.
getL2CacheHitRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Hit ratio of L2 cache.
getL2CacheMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Miss count of L2 cache.
getL2CacheMissRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Miss ratio of L2 cache.
getL2Stats() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
getLabel(int) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelOrdinalProvider
Returns the string associated with the ordinal.
getLabel(int) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
 
getLabelOrdinal(String) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelOrdinalProvider
 
getLabelOrdinal(String) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
 
getLabels() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
getLabels(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated string labels = 10;
getLabels(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
repeated string labels = 10;
getLabels(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
repeated string labels = 10;
getLabels() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
getLabels() - Method in class org.apache.hadoop.hbase.security.visibility.Authorizations
 
getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
 
getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.EnforcingScanLabelGenerator
 
getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.FeedUserAuthScanLabelGenerator
 
getLabels(User, Authorizations) - Method in interface org.apache.hadoop.hbase.security.visibility.ScanLabelGenerator
Helps to get a list of lables associated with an UGI
getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
 
getLabels() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
getLabelsBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated string labels = 10;
getLabelsBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
repeated string labels = 10;
getLabelsBytes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
repeated string labels = 10;
getLabelsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated string labels = 10;
getLabelsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
repeated string labels = 10;
getLabelsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
repeated string labels = 10;
getLabelsCount() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
 
getLabelsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
getLabelsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated string labels = 10;
getLabelsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
repeated string labels = 10;
getLabelsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
repeated string labels = 10;
getLabelsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
getLargeCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
getLargeCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getLargeCompactionThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
getLargeQueueInitSize() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
getLargestHStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getLast(long[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
 
getLast(List<T>) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
 
getLastAppliedOpAge() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
 
getLastAppliedOpAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
 
getLastAttemptAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
getLastCellIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getLastChild() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getLastCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getLastCompactSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getLastFanIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
getLastFlushedSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
getLastIndex(List<?>) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
 
getLastKey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
 
getLastKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getLastKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
getLastKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getLastKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getLastMajorCompactionAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
 
getLastMajorCompactionAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the timestamp of the last major compaction for the passed table The timestamp of the oldest HFile resulting from a major compaction of that table, or 0 if no such HFile could be found.
getLastMajorCompactionTimestamp(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getLastMajorCompactionTimestamp(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
 
getLastMajorCompactionTimestamp(RpcController, MasterProtos.MajorCompactionTimestampRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the timestamp of the last major compaction for the passed region.
getLastMajorCompactionTimestampForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getLastMajorCompactionTimestampForRegion(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
getLastMajorCompactionTimestampForRegion(RpcController, MasterProtos.MajorCompactionTimestampForRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getLastMajorCompactionTsForRegion(byte[]) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getLastMajorCompactionTsForTable(TableName) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getLastPeekedCell() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
 
getLastProcId() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
getLastQuery() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
 
getLastRecoveryTime() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
 
getLastRecoveryTime() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
getLastRegion() - Method in class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
 
getLastRegionServerUpdate() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
Get the timestamp at which the last change occurred to the list of region servers to replicate to.
getLastRowKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
TODO left from HFile version 1: move this to StoreFile after Ryan's patch goes in to eliminate KeyValue here.
getLastRowKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getLastRowKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getLastSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getLastSequenceId(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.LastSequenceId
 
getLastShippedAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
getLastShippedAge() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
getLastShippedAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
getLastTimeCheckLowReplication() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
getLastUpdate() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
getLastUpdate() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getLastUpdate() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
 
getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Get whether only the latest version of the column value should be compared.
getLeafIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getLeafIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getLeafIndexHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getLeafIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getLeafIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getLeafIndexMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getLeafWriters() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
getLeases() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getLeases() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getLeastFilledBuckets(Set<Integer>, int) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
Returns a set of indices of the buckets that are least filled excluding the offsets, we also the fully free buckets for the BucketSizes where everything is empty and they only have one completely free bucket as a reserved
getLeaves() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
 
getLeaves() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
getLegacyKeyComparatorName() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
The HFileV2 file format's trailer contains this class name.
getLegacyKeyComparatorName() - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
The HFileV2 file format's trailer contains this class name.
getLegacyKeyComparatorName() - Method in class org.apache.hadoop.hbase.KeyValue.RawBytesComparator
The HFileV2 file format's trailer contains this class name.
getLength() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Header
 
getLength() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
getLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
 
getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the length of the split.
getLength() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
getLength() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
Retrieve the maximum length (in bytes) of encoded values.
getLength() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
getLength() - Method in interface org.apache.hadoop.hbase.util.ByteRange
The length of the range.
getLength() - Method in class org.apache.hadoop.hbase.util.Bytes
 
getLength() - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
 
getLevel0Files() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
 
getLevel0Files() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getLevel0MinFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
 
getLimit() - Method in class org.apache.hadoop.hbase.client.Scan
 
getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getLimit() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
 
getLimit() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
 
getLimit() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
getLimit() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Return the current limit
getLimit__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
 
getListener() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getListener() - Method in class org.apache.hadoop.hbase.executor.EventHandler
 
getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler.Context
 
getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
Return the socket (ip+port) on which the RPC server is listening to.
getListenerAddress() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
 
getListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get a copy of current registered listeners
getListOfRegionServers() - Method in interface org.apache.hadoop.hbase.replication.ReplicationTracker
Returns a list of other live region servers in the cluster.
getListOfRegionServers() - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
Return a snapshot of the current region servers.
getListOfReplicators() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Get a list of all region servers that have outstanding replication queues.
getListOfReplicators() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get a list of all region servers that have outstanding replication queues.
getListOfReplicators() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getListOfReplicators() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getListOfReplicatorsZK() - Method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
Subclasses that use ZK explicitly can just call this directly while classes that are trying to hide internal details of storage can wrap the KeeperException into a ReplicationException or something else.
getLiveMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getLiveNode(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
getLiveNodes() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
getLiveNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveNodesOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
getLiveRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getLiveServers() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
 
getLoad(ServerName) - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getLoad(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
getLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
Originally, this method factored in the effect of requests going to the server as well.
getLoadBalancer(Configuration) - Static method in class org.apache.hadoop.hbase.master.balancer.LoadBalancerFactory
Create a loadbalancer from the given conf.
getLoadBalancer() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getLoadBalancer() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getLoadBalancerClassName() - Method in class org.apache.hadoop.hbase.master.HMaster
Fetch the configured LoadBalancer class name.
getLoadColumnFamiliesOnDemandValue() - Method in class org.apache.hadoop.hbase.client.Query
Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
getLoadedCachedBlocksByFile(Configuration, BlockCache) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
Get a BlockCacheUtil.CachedBlocksByFile instance and load it up by iterating content in BlockCache.
getLoadedCoprocessors() - Static method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
getLoadedCoprocessors() - Static method in class org.apache.hadoop.hbase.master.HMaster
The set of loaded coprocessors is stored in a static set.
getLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getLoadSequence() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
 
getLoadSequence() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getLoadStatistics() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getLocalConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
getLocalFs(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
Wrap a LocalFileSystem within a HFileSystem.
getLocalTableDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getLocation(boolean) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
getLocation() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getLocation() - Method in class org.apache.hadoop.hbase.rest.client.Response
 
getLocation() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
 
getLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional string location = 5;
getLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
optional string location = 5;
getLocation() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
optional string location = 5;
getLocationBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional string location = 5;
getLocationBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
optional string location = 5;
getLocationBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
optional string location = 5;
getLocations() - Method in class org.apache.hadoop.hbase.io.FileLink
 
getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
 
getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the region's location as an array.
getLocationSeqNum() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getLock() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
 
getLock(long) - Method in class org.apache.hadoop.hbase.util.IdReadWriteLock
Get the ReentrantReadWriteLock corresponding to the given id
getLockedRows() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getLockEntry(long) - Method in class org.apache.hadoop.hbase.util.IdLock
Blocks until the lock corresponding to the given id is acquired.
getLockPath(String, List<String>) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Determine based on a list of children under a ZNode, whether or not a process which created a specified ZNode has obtained a lock.
getLockPath(String, List<String>) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessReadLock
Determine based on a list of children under a ZNode, whether or not a process which created a specified ZNode has obtained a lock.
getLockPath(String, List<String>) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessWriteLock
Determine based on a list of children under a ZNode, whether or not a process which created a specified ZNode has obtained a lock.
getLockZNode(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getLog(HRegionInfo) - Method in class org.apache.hadoop.hbase.util.MetaUtils
 
getLogCleaner() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getLogDir() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Get the directory where wals are stored by their RSs
getLogFilePath(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
getLogFileSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
getLogFileSize() - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
iff the given WALFactory is using the DefaultWALProvider for meta and/or non-meta, count the size of files (rolled and active).
getLogFileSize() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
getLogFileSize() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
Get size of the log files this provider is managing
getLogId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
getLogPosition(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Get the current position for a specific WAL in a given queue.
getLogPosition(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getLogRecoveryMode() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
getLogsCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
getLogSeqNum() - Method in class org.apache.hadoop.hbase.wal.WALKey
 
getLogsInQueue(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Get a list of all WALs in the given queue.
getLogsInQueue(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get a list of all WALs in the given queue on the given region server.
getLogsInQueue(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getLogsInQueue(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getLogsSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
getLong(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.TimestampDecoder
methods
getLong(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
getLong() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
getLong(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Retrieve the long value at index
getLong() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Retrieve the next long value from this range.
getLong(byte[]) - Static method in class org.apache.hadoop.hbase.util.vint.UVLongTool
bytes -> long
getLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.vint.UVLongTool
 
getLong(InputStream) - Static method in class org.apache.hadoop.hbase.util.vint.UVLongTool
 
getLongValue() - Method in class org.apache.hadoop.hbase.hbtop.field.Size
get the value
getLowestTimestamp(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
Gets lowest timestamp from candidate StoreFiles
getLruCacheSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
 
getMajorCompactedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getMajorCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of cells processed during major compactions.
getMajorCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getMajorCompactedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getMajorCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the total amount of data processed during major compactions, in bytes.
getMajorCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getMajorCompactionJitter() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getMajorCompactionPeriod() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
Returns the major version of this HFile format
getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
 
getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
 
getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
 
getMap() - Method in class org.apache.hadoop.hbase.client.Result
Map of families to all versions of its qualifiers and values.
getMapperClass(JobContext) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
Get the application's mapper class.
getMaster() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Returns a MasterKeepAliveConnection to the active master
getMaster() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getMaster() - Method in class org.apache.hadoop.hbase.ClusterStatus
Returns detailed information about the current master ServerName.
getMaster() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
 
getMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getMaster() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
 
getMaster() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl.ImplData
 
getMaster() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getMaster() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
 
getMaster() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread
 
getMasterActiveTime() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMasterAddress() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get the address of the current master if one is available.
getMasterAddress(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get the address of the current master if one is available.
getMasterAddress(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get master address.
getMasterAddressTracker() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getMasterAddressZNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getMasterConfiguration() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
getMasterCoprocessorHost() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMasterCoprocessorHost() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getMasterCoprocessorHost() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
getMasterCoprocessors() - Method in interface org.apache.hadoop.hbase.client.Admin
Helper delegage to getClusterStatus().getMasterCoprocessors().
getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMasterFileSystem() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMasterFileSystem() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getMasterFinishedInitializationTime() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.client.Admin
Get the info port of the current master if one is available.
getMasterInfoPort() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getMasterInfoPort() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get the info port of the current master of one is available.
getMasterInfoPort(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Get master info port.
getMasterInitializationTime() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get the time in Millis when the master finished initializing/becoming the active master
getMasterInitializationTime() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getMasterProcedureExecutor() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMasterProcedureExecutor() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getMasterProcedureManagerHost() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMasterProcedureManagerHost() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getMasterQuotaManager() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMasterQuotaManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getMasterQuotaManager(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
getMasterRpcServices() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getMasterServices() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
 
getMasterServices() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
getMasterStartTime() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMasterSystemTime() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
 
getMasterSystemTime() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
 
getMatchingNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
 
getMax(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
Gives the maximum for a given combination of column qualifier and column family, in the given row range as defined in the Scan object.
getMax() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
 
getMax() - Method in class org.apache.hadoop.hbase.io.TimeRange
 
getMax() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
 
getMax() - Method in class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
 
getMax() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Returns the highest value in the snapshot.
getMax() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
getMax() - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
getMax() - Method in class org.apache.hadoop.metrics2.lib.MutableHistogram
 
getMaxAllowedOperationTime() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
 
getMaxAttempts() - Method in class org.apache.hadoop.hbase.util.RetryCounter
 
getMaxAttempts() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
 
getMaxChunkSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
 
getMaxColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMaxCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
 
getMaxCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getMaxCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getMaxCompactSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getMaxElementLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
getMaxFileDescriptorCount() - Method in class org.apache.hadoop.hbase.util.JVM
Get the number of the maximum file descriptors the system can use.
getMaxFileSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns the maximum size upto which a region can grow to after which a region split is triggered.
getMaxFilesToCompact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getMaxFlushedSeqId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getMaxFlushedSeqId() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getMaxFlushQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
 
getMaxFlushQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getMaxFold(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
 
getMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int32 maxHeapSizeMB = 5;
getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
optional int32 maxHeapSizeMB = 5;
getMaxHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
optional int32 maxHeapSizeMB = 5;
getMaximumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getMaxKeys() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
 
getMaxKeys(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
 
getMaxKeys() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
getMaxKeys() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
 
getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getMaxKeyValueSize(Configuration) - Static method in class org.apache.hadoop.hbase.client.HTable
 
getMaxLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getMaxLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getMaxMasterTimeout(Configuration, HBaseProtos.SnapshotDescription.Type, long) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
 
getMaxMemstoreTS() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getMaxMemstoreTS() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getMaxMemstoreTS() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getMaxMemstoreTSInList(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
Return the largest memstoreTS found across all storefiles in the given list.
getMaxMerge() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
getMaxOverlapsToSideline() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
getMaxPoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getMaxPoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getMaxPriority() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
getMaxProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
getMaxProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
getMaxQualifierLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getMaxQueueSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getMaxQueueSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getMaxRegions(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.Scan
 
getMaxResultSize() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
 
getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's maximum number of values to return per Column Family
getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
 
getMaxRowLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getMaxRowTreeStackNodes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
getMaxSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getMaxSequenceId() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getMaxSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getMaxSequenceIdInList(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
Return the highest sequence ID found across all storefiles in the given list.
getMaxSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Returns the Max size of the block cache, in bytes.
getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the maximum size of this cache.
getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
getMaxSleepTime() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
 
getMaxSplitImbalance() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
 
getMaxStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
getMaxStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getMaxStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getMaxStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
 
getMaxStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getMaxStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getMaxStoreSeqId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getMaxStoreSeqId() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getMaxTables(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
getMaxTagsLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getMaxThroughput() - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
getMaxTime() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
 
getMaxTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getMaxValue() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
returns the maximum value for this type T
getMaxValues() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's maximum number of version
getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional int32 maxVersions = 4;
getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional int32 maxVersions = 4;
getMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional int32 maxVersions = 4;
getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 maxVersions = 7;
getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int32 maxVersions = 7;
getMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int32 maxVersions = 7;
getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getMD5AsHex(byte[]) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
Given a byte array, returns in MD5 hash as a hex string.
getMD5AsHex(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
Given a byte array, returns its MD5 hash as a hex string.
getMean() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
 
getMean() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
 
getMean() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Returns the arithmetic mean of the values in the snapshot.
getMean() - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
getMean() - Method in class org.apache.hadoop.hbase.util.RollingStatCalculator
 
getMeanRate() - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
 
getMeanRate() - Method in interface org.apache.hadoop.hbase.metrics.Meter
Returns the mean rate at which events have occurred since the meter was created.
getMechanismName() - Method in enum org.apache.hadoop.hbase.security.AuthMethod
Return the SASL mechanism name
getMedian(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
Gives a List containing sum of values and sum of weights.
getMedian() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Returns the median value in the distribution.
getMemberName() - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
Each subprocedure is being executed on a member.
getMemberName() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
 
getMemberName() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
 
getMemFree() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the currently available memory for this LRU in bytes.
getMemMax() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the maximum memory allowed for this LRU in bytes.
getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns the size of the memstore after which a flush to filesystem is triggered.
getMemstoreFlushSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getMemstoreFlushSize() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
 
getMemstoreLoadPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
getMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
 
getMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getMemstoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the size of the memstore on this region server.
getMemstoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
Get the size of the memstore on this region server.
getMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getMemstoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getMemstoreSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 memstoreSizeMB = 5;
getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 memstoreSizeMB = 5;
getMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 memstoreSizeMB = 5;
getMemstoresSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
Get the memory store size against this table
getMemstoresSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
 
getMemUsed() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the currently used memory for this LRU in bytes.
getMergedRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
 
getMergedRegionInfo(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
Get merged region info through the specified two regions
getMergedRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
 
getMergePlanCount() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMergePlanCount() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get the number of region merge plans executed.
getMergePlanCount() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getMergeRegions(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getMergeRegions(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the merge regions by reading the corresponding columns of the catalog table Result.
getMergeThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
getMessage() - Method in exception org.apache.hadoop.hbase.backup.FailedArchiveException
 
getMessage() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
getMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
getMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
getMessage() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
getMessage() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
getMetaBlock(String, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getMetaBlock(String, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
getMetaData() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
For use by bucketcache.
getMetadataValue(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
Only used by the Striped Compaction Policy
getMetaHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getMetaHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getMetaHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getMetaIndexCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getMetaKeyForRegion(HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the row key to use for this regionInfo
getMetaLocation() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getMetaLocation__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getMetaMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getMetaMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getMetaMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getMetaOperationTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getMetaRegion() - Method in class org.apache.hadoop.hbase.util.MetaUtils
 
getMetaRegionLocation(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Gets the meta region location, if available.
getMetaRegionLocation(ZooKeeperWatcher, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Gets the meta region location, if available.
getMetaRegions(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
getMetaRegions(ZooKeeperWatcher, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
getMetaRegionsAndLocations(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
getMetaRegionsAndLocations(ZooKeeperWatcher, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
getMetaRegionState(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Load the meta region state from the meta server ZNode.
getMetaRegionState(ZooKeeperWatcher, int) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Load the meta region state from the meta server ZNode.
getMetaReplicaCallTimeoutMicroSecondScan() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getMetaReplicaIdFromZnode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Parse the meta replicaId from the passed znode
getMetaReplicaNodes() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get the znodes corresponding to the meta replicas from ZK
getMetaTableLocator() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getMetaTableLocator() - Method in interface org.apache.hadoop.hbase.Server
Returns instance of MetaTableLocator running inside this server.
getMetaWAL(byte[]) - Method in class org.apache.hadoop.hbase.wal.WALFactory
 
getMetaWALProvider() - Method in class org.apache.hadoop.hbase.wal.WALFactory
 
getMetaWriter() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
Get a writable interface into bloom filter meta data.
getMetaWriter() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
getMetaWriter() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
 
getMeter() - Method in class org.apache.hadoop.hbase.metrics.impl.TimerImpl
 
getMeter() - Method in interface org.apache.hadoop.hbase.metrics.Timer
 
getMethod() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
getMethod() - Method in interface org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.HttpInteraction
Returns the method.
getMetricRegistries() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
 
getMetricRegistries() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
Returns MetricRegistry's created.
getMetricRegistryForMaster() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
Returns a MetricRegistry that can be used to track metrics at the master level.
getMetricRegistryForRegionServer() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
Returns a MetricRegistry that can be used to track metrics at the region server level.
getMetricRegistryForRegionServer() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
Returns a MetricRegistry that can be used to track metrics at the region server level.
getMetricRegistryForRegionServer() - Method in interface org.apache.hadoop.hbase.coprocessor.WALCoprocessorEnvironment
Returns a MetricRegistry that can be used to track metrics at the region server level.
getMetricRegistryInfo() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
 
getMetricRegistryInfo() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
getMetricRegistryInfo() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
getMetricRegistryInfo() - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
Return the MetricRegistryInfo object for this registry.
getMetricRegistryInfo() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
getMetricRegistryInfo() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
getMetricRegistryInfo() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
getMetricRegistryInfos() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
 
getMetricRegistryInfos() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
Returns MetricRegistryInfo's for the MetricRegistry's created.
getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
 
getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
getMetrics() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
Returns the metrics instance for reporting RPC call statistics
getMetrics() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
Returns the metrics instance for reporting RPC call statistics
getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSourceImpl
 
getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
 
getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
 
getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
getMetrics() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
getMetrics() - Method in interface org.apache.hadoop.hbase.metrics.MetricSet
A map of metric names to metrics.
getMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
Yes this is a get function that doesn't return anything.
getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
Yes this is a get function that doesn't return anything.
getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
Yes this is a get function that doesn't return anything.
getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
getMetrics() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getMetrics() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getMetrics() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
Get the metrics instance.
getMetrics() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
getMetricsContext() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Get the metrics context.
getMetricsContext() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
getMetricsContext() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
Get the metrics context.
getMetricsContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
getMetricsContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
getMetricsContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
getMetricsDescription() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Get the description of what this source exposes.
getMetricsDescription() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
getMetricsDescription() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
Get the description of what this source exposes.
getMetricsDescription() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
getMetricsDescription() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
getMetricsDescription() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
getMetricsJmxContext() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Get the name of the context in JMX that this source will be exposed through.
getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
Get the name of the context in JMX that this source will be exposed through.
getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
getMetricsMap() - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
Get all of the values since the last time this function was called.
getMetricsMap(boolean) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
Get all of the values.
getMetricsName() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Get the name of the metrics that are being exported by this source.
getMetricsName() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
getMetricsName() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
Get the name of the metrics that are being exported by this source.
getMetricsName() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
getMetricsName() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
getMetricsName() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
getMetricsProcSource() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
 
getMetricsProcSource() - Method in class org.apache.hadoop.hbase.master.MetricsMaster
 
getMetricsRegistry() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
getMetricsSource() - Method in class org.apache.hadoop.hbase.io.MetricsIO
 
getMetricsSource() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
 
getMetricsSource() - Method in class org.apache.hadoop.hbase.master.MetricsMaster
 
getMetricsSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
getMetricsSource() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
 
getMidpoint(KeyValue.KVComparator, Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
Try to return a Cell that falls between left and right but that is shorter; i.e.
getMillisFromLastRoll() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
getMillisToNextPeriodicRoll() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
getMin() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
get/set
getMin(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
Gives the minimum for a given combination of column qualifier and column family, in the given row range as defined in the Scan object.
getMin() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
Gets the minimum timestamp requested by filter.
getMin() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
 
getMin() - Method in class org.apache.hadoop.hbase.io.TimeRange
 
getMin() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
 
getMin() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Returns the lowest value in the snapshot.
getMin() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
getMin() - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
getMinColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMinCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getMinFilesToCompact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getMinimumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getMinIndexNumEntries(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
 
getMinLocalityToForceCompact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getMinMvccVersion() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getMinorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
Returns the minor version of this HFile format
getMinorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
 
getMinorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
 
getMinProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
getMinProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
getMinProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
getMinStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
getMinStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getMinStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getMinStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
 
getMinStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getMinStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getMinTimestamp() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getMinValue() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
getMinVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getMinVersions() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
 
getMisplacedRegions(Map<HRegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
getMissCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getMissCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getMissCachingRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getMissCount() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the number of misses to the map.
getMissing() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
 
getMissingLogsCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
getMissingStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
getMissRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getMode() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
getModificationTime() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
getModificationTimeStamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getMonitor() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
 
getMput() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
mutation for the put
getMServerWrap() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.ImplData
 
getMTime() - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
getMultiple(ByteBuffer, List<TGet>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
getMultiple(ByteBuffer, List<TGet>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
getMultiple(ByteBuffer, List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
getMultiple(ByteBuffer, List<TGet>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Method for getting multiple rows.
getMultiple(ByteBuffer, List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
getMultiple(long, int, byte[]) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
Transfers bytes from this buffer array into the given destination array
getMultiple(long, int, byte[], int) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
Transfers bytes from this buffer array into the given destination array
getMultipleRowResource(String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
 
getMutations() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
getMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
getMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
list of mutation commands
getMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
list of mutation commands
getMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
getMutationsFromWALEntry(AdminProtos.WALEntry, CellScanner, Pair<WALKey, WALEdit>, Durability) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
This function is used to construct mutations from a WALEntry.
getMutationsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
getMutationsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
getMutationsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
getMutationsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
getMutationsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
getMutationsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
getMutationsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
getMutationsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
getMVCC() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getMvcc() - Method in class org.apache.hadoop.hbase.wal.WALKey
 
getMvccFromOperationContext(long, long) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
Return the write point of the previous succeed operation.
getMvccReadPoint(Scan) - Static method in class org.apache.hadoop.hbase.client.PackagePrivateFieldAccessor
 
getMvccReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
 
getMvccVersion() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
as of 1.0, use Cell.getSequenceId() Internal use only. A region-specific sequence ID given to each operation. It always exists for cells in the memstore but is not retained forever. It may survive several flushes, but generally becomes irrelevant after the cell's row is no longer involved in any operations that require strict consistency.
getMvccVersion() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getMvccVersion(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.MvccVersionDecoder
methods
getMvccVersion() - Method in class org.apache.hadoop.hbase.KeyValue
Here be dragons
getMvccVersion() - Method in class org.apache.hadoop.hbase.TagRewriteCell
Deprecated.
getMvccVersionDeltaWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getMvccVersionEncoder() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getMvccVersionIndex(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getMvccVersionIndexWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getMvccVersions() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getMWrap() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.ImplData
 
getMyEphemeralNodeFileName() - Static method in class org.apache.hadoop.hbase.ZNodeClearer
Get the name of the file used to store the znode contents
getName() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
getName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
getName() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
 
getName() - Method in class org.apache.hadoop.hbase.client.HTable
 
getName() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
getName() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Gets the fully qualified table name instance of this table.
getName() - Method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
 
getName() - Method in interface org.apache.hadoop.hbase.client.Table
Gets the fully qualified table name instance of this table.
getName() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
 
getName() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
getName() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
getName() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
getName() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Return this Cipher's name
getName() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
Return the provider's name
getName() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
 
getName() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getName() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
Returns this reader's "name".
getName() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
getName() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
 
getName() - Method in class org.apache.hadoop.hbase.procedure.Procedure
 
getName() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
 
getName() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getName() - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
 
getName() - Method in exception org.apache.hadoop.hbase.regionserver.Leases.LeaseStillHeldException
 
getName() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
Human readable name of the processor
getName() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getName() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
getName() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
getName() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
getName() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
 
getName() - Method in class org.apache.hadoop.hbase.rest.model.TableModel
 
getName() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
 
getName() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
required string name = 1;
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
required string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional string name = 1;
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
required string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
required string name = 1;
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
required string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
required bytes name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
required bytes name = 1;
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
required bytes name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
required string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
required string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
required string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
required string name = 1;
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
required string name = 1;
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
required string name = 1;
getName(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
repeated string name = 1;
getName(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
repeated string name = 1;
getName(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
repeated string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
required string name = 1;
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
required string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
optional string name = 1;
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
optional string name = 1;
getName() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Get group name.
getName() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
getName() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
getName() - Method in class org.apache.hadoop.hbase.security.User
Returns the full user name.
getName() - Method in class org.apache.hadoop.hbase.TableName
 
getName() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
getName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
getName() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
returns the name of this checksum type
getName() - Method in class org.apache.hadoop.hbase.util.HasThread
 
getName() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
 
getNameAsString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getNameAsString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Get the name of the table as a String
getNameAsString() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getNameAsString() - Method in class org.apache.hadoop.hbase.TableName
 
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
required string name = 1;
getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
required string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional string name = 1;
getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
required string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
required string name = 1;
getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
required string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
required string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
required string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
required string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
required string name = 1;
getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
required string name = 1;
getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
required string name = 1;
getNameBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
repeated string name = 1;
getNameBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
repeated string name = 1;
getNameBytes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
repeated string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
required string name = 1;
getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
required string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional string name = 1;
getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
optional string name = 1;
getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
optional string name = 1;
getNameCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
repeated string name = 1;
getNameCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
repeated string name = 1;
getNameCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
repeated string name = 1;
getNamedThreadFactory(String) - Static method in class org.apache.hadoop.hbase.util.Threads
Returns a ThreadFactory that names each created thread uniquely, with a common prefix.
getNameForThrottling(Store, String) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.ThroughputControlUtil
Generate a name for throttling, to prevent name conflict when multiple IO operation running parallel on the same store.
getNameFromId(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Find and return the name of data block encoder for the given id.
getNameInBytes() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
getNameList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
repeated string name = 1;
getNameList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
repeated string name = 1;
getNameList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
repeated string name = 1;
getNamespace() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getNamespace() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
Get the name of the namespace this table is in.
getNamespace() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getNamespace(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
repeated string namespace = 1;
getNamespace(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
repeated string namespace = 1;
getNamespace(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.NamespacesOrBuilder
repeated string namespace = 1;
getNamespace() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
getNamespace() - Method in class org.apache.hadoop.hbase.TableName
 
getNamespaceAsString() - Method in class org.apache.hadoop.hbase.TableName
 
getNamespaceBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
repeated string namespace = 1;
getNamespaceBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
repeated string namespace = 1;
getNamespaceBytes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.NamespacesOrBuilder
repeated string namespace = 1;
getNamespaceCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
repeated string namespace = 1;
getNamespaceCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
repeated string namespace = 1;
getNamespaceCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.NamespacesOrBuilder
repeated string namespace = 1;
getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Get a namespace descriptor by name
getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get a namespace descriptor by name
getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.master.HMaster
 
getNamespaceDescriptor(RpcController, MasterProtos.GetNamespaceDescriptorRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Get a namespace descriptor by name
getNamespaceDir(Path, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Returns the Path object representing the namespace directory under path rootdir
getNamespaceFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getNamespaceFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getNamespaceInstanceResource(String) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
Dispatch to NamespaceInstanceResource for getting list of tables.
getNamespaceInstanceResource(String) - Method in class org.apache.hadoop.hbase.rest.NamespacesResource
Dispatch to NamespaceInstanceResource
getNamespaceLimiter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
Returns the limiter associated to the specified namespace.
getNamespaceList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
repeated string namespace = 1;
getNamespaceList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
repeated string namespace = 1;
getNamespaceList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.NamespacesOrBuilder
repeated string namespace = 1;
getNamespaceName() - Method in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
 
getNamespacePermissions(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
 
getNamespaceQueue() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler.TableQueue
 
getNamespaceQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getNamespaceQuotaManager() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
getNamespaceResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
 
getNamespaceRowKey(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getNamespaceRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getNamespaces() - Method in class org.apache.hadoop.hbase.rest.model.NamespacesModel
 
getNameWithNamespaceInclAsString() - Method in class org.apache.hadoop.hbase.TableName
Ideally, getNameAsString should contain namespace within it, but if the namespace is default, it just returns the name.
getNbRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
number of results to return
getNegativeIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getNewAssignmentPlan() - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
 
getNewByteArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
writing back to byte[]'s
getNewRpcRetryingCallerFactory(Configuration) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Returns a new RpcRetryingCallerFactory from the given Configuration.
getNextBlockOnDiskSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is the next key it must seek to.
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterBase
Filters that are not sure which key must be next seeked to, can inherit this implementation that, by default, returns a null Cell.
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
Pick the next cell that the scanner should seek to.
getNextCellStartPosition() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
getNextCellStartPosition() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
 
getNextIndexedKey() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
 
getNextIndexedKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
getNextIndexedKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
getNextIndexedKey() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
 
getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
 
getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.Filter
Deprecated.
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterBase
Deprecated.
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
Deprecated.
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
Deprecated.
getNextKeyHint(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
getNextKeyHint(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.LegacyScanQueryMatcher
Deprecated.
 
getNextKeyHint(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
getNextKeyHint(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
getNextMajorCompactTime(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
 
getNextMode() - Method in class org.apache.hadoop.hbase.hbtop.mode.DrillDownInfo
 
getNextNodeOffset(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getNextNodeOffsetWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNextPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns the next pointer for the entry in teh LRU.
getNextQueue() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor.QueueBalancer
 
getNextRefillTime() - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
 
getNextRefillTime() - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
 
getNextRefillTime() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
 
getNextRowOrNextColumn(byte[], int, int) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
Retrieve the MatchCode for the next row or column
getNextRowOrNextColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
 
getNextRowOrNextColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
 
getNextSequenceId(WAL) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Method to safely get the next sequence number.
getNextSleepInterval(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
Get how long the caller should sleep according to the current size and current cycle's total push size and start tick, return the sleep interval for throttling control.
getNoChecksumFs() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
Returns the filesystem that is specially setup for doing reads from storage.
getNode(TokenizerRowSearchResult, byte[], int, int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
getNode(TokenizerRowSearchResult, byte[], int, int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
searching
getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
Deprecated.
 
getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
getNodeDepth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
simple read-only methods
getNodeName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the full path node name for the unassigned node for the specified region.
getNodeName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the name of the current node from the specified fully-qualified path.
getNodes(boolean, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
getNonce() - Method in class org.apache.hadoop.hbase.client.Action
 
getNonce() - Method in class org.apache.hadoop.hbase.util.NonceKey
 
getNonce() - Method in class org.apache.hadoop.hbase.wal.WALKey
 
getNonceGenerator() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getNonceGenerator() - Method in class org.apache.hadoop.hbase.client.CoprocessorHConnection
 
getNonceGenerator() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getNonceGroup() - Method in class org.apache.hadoop.hbase.client.MultiAction
 
getNonceGroup() - Method in interface org.apache.hadoop.hbase.client.NonceGenerator
 
getNonceGroup() - Method in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
 
getNonceGroup() - Method in class org.apache.hadoop.hbase.util.NonceKey
 
getNonceGroup() - Method in class org.apache.hadoop.hbase.wal.WALKey
 
getNonceKey() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
 
getNonceKey() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
getNonceKey() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getNonceManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getNonceManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
Only required for "old" log replay; if it's removed, remove this.
getNonLeafWriters() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
getNonLeaves() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
 
getNonLeaves() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
getNonSharedArchivedStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
getNoVersionMap() - Method in class org.apache.hadoop.hbase.client.Result
Map of families to their most recent qualifiers and values.
getNullPollCalls() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
getNumAdded() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
read
getNumAtOrBelow(long) - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
 
getNumAtOrBelow(long) - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
getNumber() - Method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
 
getNumberOfCachedRegionLocations(TableName) - Method in class org.apache.hadoop.hbase.client.MetaCache
Return the number of cached region for a table.
getNumberOfChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the number of children of the specified node.
getNumberOfListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getNumberOfOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getNumberOfRecoveredRegions() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
getNumberOfRegions() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getNumberOfRunningProcess() - Method in class org.apache.hadoop.hbase.util.JVM
Workaround to get the current number of process running.
getNumberOfThreads(JobContext) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
The number of threads in the thread pool that will run the map function.
getNumBranchNodesIncludingThisNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
count different node types
getNumBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
 
getNumBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
get/set
getNumBytesCompacted() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
 
getNumBytesCompacted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getNumCells() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getNumChildren() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getNumChunks() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
 
getNumCompactionsCompleted() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
 
getNumCompactionsCompleted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getNumCompactionsFailed() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
Returns the total number of compactions that have been reported as failed on this region.
getNumCompactionsFailed() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getNumCompactionsQueued() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
 
getNumCompactionsQueued() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getNumDeadRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get the number of dead region servers
getNumDeadRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getNumExceptions() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getNumFamilyBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumFilesCompacted() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
 
getNumFilesCompacted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getNumFlushesQueued() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
 
getNumFlushesQueued() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
getNumGeneralCallsDropped() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
If CoDel-based RPC executors are used, retrieves the number of Calls that were dropped from general queue because RPC executor is under high load; returns 0 otherwise.
getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
getNumHFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getNumHFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getNumKeyValueBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumLeafNodesIncludingThisNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getNumLevels() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
 
getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
getNumLifoModeSwitches() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
If CoDel-based RPC executors are used, retrieves the number of Calls that were picked from the tail of the queue (indicating adaptive LIFO mode, when in the period of overloade we serve last requests first); returns 0 otherwise.
getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
getNumLogFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
getNumLogFiles() - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
iff the given WALFactory is using the DefaultWALProvider for meta and/or non-meta, count the number of files (rolled and active).
getNumLogFiles() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
getNumLogFiles() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
Get number of the log files this provider is managing
getNumMetaBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumMutationsWithoutWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getNumMutationsWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Number of mutations received with WAL explicitly turned off.
getNumMutationsWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getNumMvccVersionBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumNubNodesIncludingThisNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getNumObservers() - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
 
getNumOccurrences() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getNumOfDeletedLargeFiles() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
getNumOfDeletedSmallFiles() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
getNumOnlineRegions() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
The number of online regions
getNumOpenConnections() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getNumOpenConnections() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getNumPositivesForTesting(int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
 
getNumQualifierBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumQueriesForTesting(int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
 
getNumReferenceFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getNumReferenceFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getNumReferenceFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
 
getNumReferenceFiles() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getNumReferenceFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getNumRegions() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
 
getNumRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get the number of live region servers
getNumRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getNumRegionsOpened() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Used by unit tests.
getNumRolledLogFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
getNumRolledLogFiles(WAL) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
returns the number of rolled WAL files.
getNumRootEntries() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
 
getNumRowBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
number of rows to return
getNumRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
number of rows to return
getNumSinks() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
 
getNumStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of store files hosted on this region server.
getNumStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
Get the number of store files hosted on this region server.
getNumStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getNumStores() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of stores hosted on this region server.
getNumStores() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
Get the number of stores hosted on this region server.
getNumStores() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getNumTagsBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumThreads() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
getNumThreads() - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
 
getNumThreads() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
 
getNumThreads() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
getNumTimestampBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumUniqueFamilies() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumUniqueQualifiers() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumUniqueRows() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumUniqueTags() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumUniqueValues() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
getNumValueBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
number of versions to retrieve
getNumVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
number of versions to retrieve
getNumWALFiles() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getNumWALFiles() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get the number of master WAL files.
getNumWALFiles() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getNumWALFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of WAL files of this region server.
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.NamespacesModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
 
getObjectFromMessage(byte[]) - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
Initialize the model from a protobuf representation.
getOffPeakHours() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getOffPeakMaxCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
getOffset() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
getOffset() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
 
getOffset() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
getOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getOffset() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
getOffset() - Method in interface org.apache.hadoop.hbase.util.ByteRange
The offset, the index into the underlying byte[] at which this range begins.
getOffset() - Method in class org.apache.hadoop.hbase.util.Bytes
 
getOldestHfileTs(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getOldestHfileTs(boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
This can be used to determine the last time all files of this region were major compacted.
getOldestSeqIdOfStore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getOldestSeqIdOfStore(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Deprecated.
Since version 1.2.0. Exposes too much about our internals; shutting it down. Do not use.
getOldLogDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
Get the directory where old logs go
getOldLogDir() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Get the directory where wals are archived
getOldSources() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Get a list of all the old sources of this rs
getOnDiskSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getOneMinuteRate() - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
 
getOneMinuteRate() - Method in interface org.apache.hadoop.hbase.metrics.Meter
Returns the one-minute exponentially-weighted moving average rate at which events have occurred since the meter was created.
getOnlineRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
getOnlineRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get all the online regions on a region server.
getOnlineRegions(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get all the online regions on a region server.
getOnlineRegions(AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to get the all the online regions on a region server using admin protocol.
getOnlineRegions(RpcController, AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to get the all the online regions on a region server using admin protocol.
getOnlineRegions(TableName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Gets the online regions of the specified table.
getOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getOnlineRegions(TableName) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
Get all online regions of a table in this RS.
getOnlineRegions() - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
Get all online regions in this RS.
getOnlineRegions() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
 
getOnlineRegionsLocalContext() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
For tests, web ui and metrics.
getOnlineServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
 
getOnlineServers() - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
Gets the online servers.
getOnlineServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
 
getOnlineTables() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Gets the online tables in this RS.
getOnlineTables() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getOnlyType() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
 
getOpenFileDescriptorCount() - Method in class org.apache.hadoop.hbase.util.JVM
Get the number of opened filed descriptor for the runtime jvm.
getOpenRegionCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
Method to retrieve coordination for opening region operations.
getOpenRegionCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
getOpenSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getOpenSeqNum() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getOpenSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
 
getOperation(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
 
getOperationsFromCoprocessors(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
 
getOperationStatus(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
 
getOperationStatusCode() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
 
getOperationTimeout() - Method in interface org.apache.hadoop.hbase.client.Admin
 
getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
 
getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
getOperationTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
Get timeout (millisecond) of each operation for in Table instance.
getOperationTimeout() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getOperator() - Method in class org.apache.hadoop.hbase.filter.BitComparator
 
getOperator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
getOperator() - Method in class org.apache.hadoop.hbase.filter.FilterList
Get the operator.
getOperator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getOperator() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
 
getOptionAsDouble(CommandLine, String, double) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
getOptionAsInt(CommandLine, String, int) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
getOrComputeLocality(int, int, BaseLoadBalancer.Cluster.LocalityType) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
Looks up locality from cache of localities.
getOrComputeRackLocalities() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
Retrieves and lazily initializes a field storing the locality of every region/server combination
getOrComputeRegionsToMostLocalEntities(BaseLoadBalancer.Cluster.LocalityType) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
Lazily initializes and retrieves a mapping of region -> server for which region has the highest the locality
getOrComputeWeightedLocality(int, int, BaseLoadBalancer.Cluster.LocalityType) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
Returns locality weighted by region size in MB.
getOrCreate(ZooKeeperWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Returns a TableAuthManager from the cache.
getOrCreateTableHistogram(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
getOrder() - Method in interface org.apache.hadoop.hbase.types.DataType
Retrieve the sort Order imposed by this data type, or null when natural ordering is not preserved.
getOrder() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
getOrder() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
getOrder() - Method in class org.apache.hadoop.hbase.types.PBType
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawByte
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawLong
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawShort
 
getOrder() - Method in class org.apache.hadoop.hbase.types.RawString
 
getOrder() - Method in class org.apache.hadoop.hbase.types.Struct
 
getOrder() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
getOrder() - Method in class org.apache.hadoop.hbase.types.Union2
 
getOrder() - Method in class org.apache.hadoop.hbase.types.Union3
 
getOrder() - Method in class org.apache.hadoop.hbase.types.Union4
 
getOrderOfSize() - Method in enum org.apache.hadoop.hbase.hbtop.field.Size.Unit
 
getOriginalIndex() - Method in class org.apache.hadoop.hbase.client.Action
 
getOriginatingClusterId() - Method in class org.apache.hadoop.hbase.wal.WALKey
 
getOriginPath() - Method in class org.apache.hadoop.hbase.io.HFileLink
 
getOrigLogSeqNum() - Method in class org.apache.hadoop.hbase.wal.WALKey
Return a positive long if current WALKey is created from a replay edit
getOSVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
 
getOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string osVersion = 3;
getOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string osVersion = 3;
getOsVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string osVersion = 3;
getOsVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string osVersion = 3;
getOsVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string osVersion = 3;
getOsVersionBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string osVersion = 3;
getOuputStream() - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
 
getOutputArrayLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
getOutputArrayOffset(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
 
getOutputArrayOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Returns the output committer.
getOutputCounts() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
getOutputStream() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
getOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
Get a SASL wrapped OutputStream.
getOverallAverageLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getOverlapGroups(TableName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
getOwner() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
getOwnerString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
since 0.94.1
getPaddedTokenAndOccurrenceString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getPageEndPosition() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
 
getPageSize() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
getPageSize() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
 
getPageStartPosition() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
 
getParameter(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
Unquote the name and quote the value.
getParameterMap() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
 
getParameterNames() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
Return the set of parameter names, quoting each name.
getParameterValues(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
 
getParams() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
getParent() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getParent(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Returns the full path of the immediate parent of the specified node.
getParentId() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getParentProcId() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
getParentStartPosition() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
getParsedGenericInstance(Class<?>, int, ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Get an instance of the argument type declared in a class's signature.
getParserForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
getParserForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
getParserForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
getParserForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
getPartition(ImmutableBytesWritable, V2, int) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
 
getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
Gets the partition number for a given key (hence record) given the total number of partitions i.e.
getPartition(Import.KeyValueWritableComparable, KeyValue, int) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparablePartitioner
 
getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
getPassword(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Get the password from the Configuration instance using the getPassword method if it exists.
getPath() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getPath() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
 
getPath() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getPath() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
 
getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
 
getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
getPath(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Return the 'path' component of a Path.
getPath() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.AcquiredLock
 
getPath(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
 
getPath() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
 
getPauseTime(long, int) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Calculate pause time.
getPayload() - Method in class org.apache.hadoop.hbase.RegionTransition
 
getPeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Returns the ReplicationPeer
getPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getPeerBandwidth() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
Get the per node bandwidth upper limit for this peer
getPeerBandwidth() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
getPeerClusterId() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
getPeerClusterId() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
Get the id that the source is replicating to.
getPeerClusterZnode() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
getPeerClusterZnode() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
Get the id that the source is replicating to
getPeerClusterZnode() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
 
getPeerConf(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Returns the configuration needed to talk to the remote slave cluster.
getPeerConf(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getPeerConfig(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
getPeerConfig() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
Get the peer config object
getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Get the peer config object
getPeerData() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getPeerID() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Get the slave peer ID
getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
getPeerID() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
 
getPeerIds() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Returns the set of peerIds defined
getPeerIds() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getPeerNode(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
getPeersCount() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the number of slave clusters the local cluster has.
getPeerState(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the state of the specified peer cluster
getPeerState() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
Returns the state of the peer
getPeerState() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
getPeerStateNode(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
getPeerTableCFs(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the replicable table-cf config of the specified peer.
getPeerTableCFsConfig(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Get the table and column-family list of the peer from ZK.
getPeerTableCFsConfig(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getPeerUUID() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
getPeerUUID() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Returns a UUID of the provided peer id.
getPeerUUID() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
getPercentFileLocal() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the percent of HFiles' that are local.
getPercentFileLocalSecondaryRegions() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the percent of HFiles' that are local for secondary region replicas.
getPeriod() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
getPeriod() - Method in class org.apache.hadoop.hbase.util.Sleeper
 
getPhase() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.JournalEntry
 
getPhase() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl.JournalEntryImpl
 
getPhase() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction.JournalEntry
 
getPhase() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
 
getPid() - Static method in class org.apache.hadoop.hbase.util.ProcessUtils
 
getPollCalls() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
getPool() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getPool() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getPoolCompletedTaskCount() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getPoolCompletedTaskCount() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getPoolLargestPoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getPoolLargestPoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getPoolTaskCount() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getPoolTaskCount() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getPort() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getPort() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getPort() - Method in class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
getPort() - Method in class org.apache.hadoop.hbase.http.InfoServer
Deprecated.
getPort() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
getPort() - Method in class org.apache.hadoop.hbase.net.Address
 
getPort() - Method in class org.apache.hadoop.hbase.ServerName
 
getPort() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
getPort() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
getPos() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
 
getPosition() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
getPosition() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
getPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
 
getPosition() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
getPosition() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
The current position marker.
getPosition() - Method in interface org.apache.hadoop.hbase.wal.WAL.Reader
 
getPrefix() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
getPrefix() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
getPrefix() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
getPrettyHistogramReport(Histogram) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
 
getPrevPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns the previous pointer for the entry in the LRU.
getPrimaryCallTimeoutMicroSecond() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getPrimaryEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getPrimaryEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getPrimaryHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getPrimaryHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getPrimaryHRIForDeployedReplica() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
getPrimaryMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getPrimaryMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getPrimaryOperationTimeout() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getPrincipalWithoutRealm(String) - Static method in class org.apache.hadoop.hbase.security.SecurityUtil
Get the user name from a principal
getPriority() - Method in class org.apache.hadoop.hbase.client.Action
 
getPriority() - Method in class org.apache.hadoop.hbase.client.MultiAction
 
getPriority() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
getPriority() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getPriority() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
 
getPriority() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getPriority() - Method in class org.apache.hadoop.hbase.executor.EventHandler
Get the priority level for this handler instance.
getPriority() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
getPriority() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
getPriority() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
getPriority() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
 
getPriority() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
getPriority(RPCProtos.RequestHeader, Message, User) - Method in interface org.apache.hadoop.hbase.ipc.PriorityFunction
Returns the 'priority type' of the specified request.
getPriority() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
getPriority() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
 
getPriority() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
 
getPriority(RPCProtos.RequestHeader, Message, User) - Method in class org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
 
getPriority(RPCProtos.RequestHeader, Message, User) - Method in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
Returns a 'priority' based on the request type.
getPriority() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
Gets the priority for the request
getPriority() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
getPriority(RPCProtos.RequestHeader, Message, User) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
getPriorityQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Retrieves length of the priority queue for metrics.
getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
getProcedure(String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
Returns the procedure.
getProcedure(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
getProcedureExecutor() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
 
getProcedureManager(String) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
 
getProcedureManagers() - Method in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
 
getProcedureNames() - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
 
getProcedureQueue() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
getProcedureResult(MasterProtos.GetProcedureResultRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
getProcedureResult(RpcController, MasterProtos.GetProcedureResultRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
getProcedureSignature() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
getProcedureSignature() - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
 
getProcedureSignature() - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
 
getProcedureSignature() - Method in class org.apache.hadoop.hbase.procedure.ProcedureManager
Return the unique signature of the procedure.
getProcedureSignature() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
 
getProcessName() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getProcessName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getProcId() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
 
getProcId() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
getProcId() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getProcIdHashCode(long) - Static method in class org.apache.hadoop.hbase.procedure2.Procedure
Get an hashcode for the specified Procedure ID
getProcName() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getProcOwner() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getProcState() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
The current progress of the record reader through its data.
getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
The current progress of the record reader through its data.
getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
 
getProgress() - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
getProgressPct() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
getter for calculated percent complete
getPromotedValueFromProto(HBaseProtos.BigDecimalMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getPromotedValueFromProto(HBaseProtos.DoubleMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getPromotedValueFromProto(HBaseProtos.LongMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getPromotedValueFromProto(R) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method gets the promoted type from the proto message
getProperties() - Method in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
 
getProps(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getProps(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getProps(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespacePropertiesOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespacePropertiesOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespacePropertiesOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespacePropertiesOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getPropsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespacePropertiesOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
getProtobuf(UriInfo, String) - Method in class org.apache.hadoop.hbase.rest.TableScanResource
 
getProtocol() - Method in exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
getProtoForCellType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getProtoForCellType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getProtoForCellType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getProtoForCellType(T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method gets the PB message corresponding to the cell type
getProtoForPromotedType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getProtoForPromotedType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getProtoForPromotedType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getProtoForPromotedType(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method gets the PB message corresponding to the promoted type
getProvider() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Return the provider for this Cipher
getPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
getQop(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
Returns SaslUtil.QualityOfProtection corresponding to the given stringQop value.
getQualifiedPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getQualifier() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
getQualifier() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getQualifier() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
getQualifier() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
getQualifier() - Method in class org.apache.hadoop.hbase.KeyValue
Deprecated.
getQualifier(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
getQualifier() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
getQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
getQualifier() - Method in class org.apache.hadoop.hbase.TableName
 
getQualifier() - Method in class org.apache.hadoop.hbase.TagRewriteCell
Deprecated.
getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
column qualifier to check
getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
column qualifier to check
getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
column qualifier to check
getQualifierArray() - Method in interface org.apache.hadoop.hbase.Cell
Contiguous raw bytes that may start at any index in the containing array.
getQualifierArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getQualifierArray() - Method in class org.apache.hadoop.hbase.KeyValue
 
getQualifierArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getQualifierArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getQualifierAsString() - Method in class org.apache.hadoop.hbase.TableName
 
getQualifierBufferLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
getQualifierBufferShallowCopy(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
getQualifierLength() - Method in interface org.apache.hadoop.hbase.Cell
 
getQualifierLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getQualifierLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getQualifierLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getQualifierLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getQualifierOffset() - Method in interface org.apache.hadoop.hbase.Cell
 
getQualifierOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getQualifierOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getQualifierOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getQualifierOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getQualifierOffsetWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getQualifierSorter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getQualifierString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
getQualifierWriter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getQuantiles(double[]) - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
Computes the quantiles give the ratios.
getQuantiles() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
 
getQuantiles(double[]) - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Return the values with the given quantiles.
getQuantiles() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
Return the values with the default quantiles.
getQuantiles(double[]) - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
Computes the quantiles give the ratios.
getQuantiles() - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
 
getQuarantined() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
 
getQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
Returns the length of the pending queue
getQueues() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
Returns the list of request queues
getQueueSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getQueueSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getQueuesZNodeCversion() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get the cversion of replication rs node.
getQueuesZNodeCversion() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getQuorum() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get the quorum address of this instance.
getQuorumString() - Method in class org.apache.hadoop.hbase.zookeeper.ZKConfig.ZKClusterKey
 
getQuota(UserGroupInformation, TableName) - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
Returns the quota for an operation.
getQuotaRetriever(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
Return a QuotaRetriever to list the quotas based on the filter.
getQuotaRetriever(QuotaFilter) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Return a Quota Scanner to list the quotas based on the filter.
getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getRack(ServerName) - Method in class org.apache.hadoop.hbase.master.RackManager
Get the name of the rack containing a server, according to the DNS to switch mapping.
getRack(List<ServerName>) - Method in class org.apache.hadoop.hbase.master.RackManager
Same as RackManager.getRack(ServerName) except that a list is passed
getRackForRegion(int) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
Maps region index to rack index
getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create a random symmetric key
getRanges() - Method in class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
Returns the ranges to be counted
getRanges() - Method in class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
 
getRanges() - Method in class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
 
getRangeType() - Method in class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
Returns the type of range histogram size or time
getRangeType() - Method in class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
 
getRangeType() - Method in class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
 
getRaw(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
getReachedBarrierNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
getReachedBarrierNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
Get the full znode path for the node used by the coordinator to trigger a global barrier execution and release on each subprocedure.
getReadAvailable() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
getReadAvailable() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
 
getReadAvailable() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
 
getReadAvailable() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
 
getReader() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
getReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
getReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getReader() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
 
getReader(FileStatus, boolean, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
Create a new WAL.Reader for reading logs to split.
getReader(Path, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
Create a new WAL.Reader for reading logs to split.
getReadFailureCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
 
getReadFailureCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
 
getReadFailures() - Method in interface org.apache.hadoop.hbase.tool.Canary
 
getReadFailures() - Method in class org.apache.hadoop.hbase.tool.CanaryTool
 
getReadFailures() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
 
getReadFailures() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
 
getReadLatency() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
getReadLatencyMap() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
 
getReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional bool readOnly = 5;
getReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
optional bool readOnly = 5;
getReadOnly() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
optional bool readOnly = 5;
getReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.ChangedReadersObserver
 
getReadpoint(IsolationLevel) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
 
getReadpoint(IsolationLevel) - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
getReadQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Retrieves length of the read queue for metrics when use RWQueueRpcExecutor.
getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
getReadRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
Get the total number of read requests that have been issued against this region
getReadRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getReadRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
 
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of read requests to regions hosted on this region server.
getReadRequestsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
Get the number of read requests that have been issued against this table
getReadRequestsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
 
getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 readRequestsCount = 7;
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int64 readRequestsCount = 7;
getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int64 readRequestsCount = 7;
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getReadRequestsRate() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the rate of read requests per second to regions hosted on this region server.
getReadRpcTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
 
getReadRpcTimeout() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
getReadRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
Get timeout (millisecond) of each rpc read request in this Table instance.
getReadRpcTimeout() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getReadSuccessCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
 
getReadSuccessCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
 
getReadType() - Method in class org.apache.hadoop.hbase.client.Scan
 
getRealCacheSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getReason() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Builds a TableRecordReader.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
 
getRecords(ClusterStatus) - Method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
 
getRecords(ClusterStatus) - Method in class org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy
 
getRecords(ClusterStatus) - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
 
getRecords(ClusterStatus) - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
 
getRecords(ClusterStatus) - Method in class org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy
 
getRecords() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
Deprecated.
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Creates a new record writer.
getRecoverableZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get the connection to ZooKeeper.
getRecoveringRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRecoveringRegions() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getRecoveryMode() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Temporary function, mostly for UTs.
getRecoveryMode() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
getRecoveryMode() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
 
getRefCount() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
getReferencedFileStatus(FileSystem) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Get the FileStatus of the file referenced by this StoreFileInfo
getReferencedHFileName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Get the HFile name of the referenced link
getReferencedRegionName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Get the Region name of the referenced link
getReferencedTableName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Get the Table name of the referenced link
getReferenceFilePaths(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getReferredToFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
getRegion() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
getRegion() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
 
getRegion() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getRegion(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
getRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Protected utility method for safely obtaining an HRegion handle.
getRegion() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
 
getRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Find the HRegion based on a region specifier
getRegion(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
getRegion() - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
getRegionActionBuilderWithRegion(ClientProtos.RegionAction.Builder, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
 
getRegionArchiveDir(Path, TableName, Path) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
Get the archive directory for a given region under the specified table
getRegionArchiveDir(Path, TableName, String) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
Get the archive directory for a given region under the specified table
getRegionAssignments() - Method in class org.apache.hadoop.hbase.master.RegionStates
 
getRegionAssignmentsByServer(Collection<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
getRegionAssignmentsByServer() - Method in class org.apache.hadoop.hbase.master.RegionStates
Returns a clone of region assignments per server
getRegionAssignmentSnapshot() - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
 
getRegionBlockLocations(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRegionByEncodedName(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRegionByEncodedName(byte[], String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRegionByStateOfTable(TableName) - Method in class org.apache.hadoop.hbase.master.RegionStates
Gets current state of all regions of the table.
getRegionCachePrefetch(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
always return false since 0.99
getRegionCachePrefetch(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
always return false since 0.99
getRegionCachePrefetch(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
always return false since 0.99
getRegionCachePrefetch(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
always return false since 0.99
getRegionCachePrefetch(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
always return false since 0.99
getRegionCachePrefetch(TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
always return false since 0.99
getRegionCount() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
 
getRegionCount(Configuration, String) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deprecated.
getRegionCount(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Count regions in hbase:meta for passed table.
getRegionCount(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Count regions in hbase:meta for passed table.
getRegionCountOfTable(TableName) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
Get region count for table
getRegionCountOfTable(TableName) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
getRegionDegreeLocalityMappingFromFS(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
This function is to scan the root path of the file system to get the degree of locality for each region on each of the servers having at least one block of that region.
getRegionDegreeLocalityMappingFromFS(Configuration, String, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
This function is to scan the root path of the file system to get the degree of locality for each region on each of the servers having at least one block of that region.
getRegionDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
 
getRegionDirFromRootDir(Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getRegionDirFromTableDir(Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getRegionDirRecoveredEditsDir(Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
 
getRegionDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Given a particular table dir, return all the regiondirs inside it, excluding files such as .tableinfo
getRegionEncodedName(HBaseProtos.RegionSpecifier) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Find the HRegion encoded name based on a region specifier
getRegionEventDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getRegionFlushedSequenceId(String, String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
 
getRegionFlushedSequenceId(String, String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
 
getRegionFlushedSequenceId(ZooKeeperWatcher, String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
This function is used in distributedLogReplay to fetch last flushed sequence id from ZK
getRegionHashCode() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
 
getRegionHashCode() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getRegionId() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
getRegionInfo() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.master.normalizer.SplitNormalizationPlan
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.master.RegionPlan
 
getRegionInfo(byte[]) - Method in class org.apache.hadoop.hbase.master.RegionStates
Get the HRegionInfo from cache, if not there, from the hbase:meta table
getRegionInfo(RpcController, AdminProtos.AdminService.BlockingInterface, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to retrieve region info given a region name using admin protocol.
getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
 
getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getRegionInfo(ByteBuffer, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getRegionInfo(ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getRegionInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRegionInfo(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get the regininfo for the specified row.
getRegionInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
getRegionInfoColumn() - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the column qualifier for serialized region info
getRegionInfoForDefaultReplica(HRegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
Returns the HRegionInfo for the default replicaId (0).
getRegionInfoForFS() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
 
getRegionInfoForFs(HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
Returns the regionInfo object to use for interacting with the file system.
getRegionInfoForReplica(HRegionInfo, int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
Returns the HRegionInfo for the given replicaId.
getRegionInfos(AdminProtos.GetOnlineRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the list of region info from a GetOnlineRegionResponse
getRegionInfosFromManifest(SnapshotManifest) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
 
getRegionLocation(TableName, byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Find region location hosting passed row
getRegionLocation(TableName, byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
getRegionLocation(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getRegionLocation(byte[]) - Method in class org.apache.hadoop.hbase.client.HRegionLocator
Finds the region on which the given row is being served.
getRegionLocation(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HRegionLocator
Finds the region on which the given row is being served.
getRegionLocation(String) - Method in class org.apache.hadoop.hbase.client.HTable
getRegionLocation(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
getRegionLocation(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HTable
getRegionLocation(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Finds the region on which the given row is being served.
getRegionLocation(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Finds the region on which the given row is being served.
getRegionLocation() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getRegionLocation() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the region location.
getRegionLocation(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the HRegionLocation from meta for the given region
getRegionLocation(Connection, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the HRegionLocation from meta for the given region
getRegionLocation(int) - Method in class org.apache.hadoop.hbase.RegionLocations
 
getRegionLocation() - Method in class org.apache.hadoop.hbase.RegionLocations
Returns the first not-null region location in the list
getRegionLocation(ByteBuffer, ByteBuffer, boolean, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
getRegionLocation(ByteBuffer, ByteBuffer, boolean, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
getRegionLocation(ByteBuffer, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
getRegionLocation(ByteBuffer, ByteBuffer, boolean) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Given a table and a row get the location of the region that would contain the given row key.
getRegionLocation(ByteBuffer, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
getRegionLocationByRegionName(byte[]) - Method in class org.apache.hadoop.hbase.RegionLocations
Returns the region location from the list for matching regionName, which can be regionName or encodedRegionName
getRegionLocations() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
This is no longer a public API. Use HTable.getAllRegionLocations() instead.
getRegionLocations(ClusterConnection, TableName, byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
getRegionLocations(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns an HRegionLocationList extracted from the result.
getRegionLocations() - Method in class org.apache.hadoop.hbase.RegionLocations
 
getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a RegionLocator implementation to inspect region information on a table.
getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve a RegionLocator implementation to inspect region information on a table.
getRegionLocator() - Method in class org.apache.hadoop.hbase.client.HTable
 
getRegionLocator() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to get the RegionLocator.
getRegionLocator(byte[]) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
Retrieve a regionLocator for the table.
getRegionManifests() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Get all the Region Manifest from the snapshot
getRegionManifestsMap() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Get all the Region Manifest from the snapshot.
getRegionMap() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
 
getRegionMergeCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
Method to retrieve coordination for region merge transaction
getRegionMergeCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
getRegionName() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionName() - Method in class org.apache.hadoop.hbase.master.RegionPlan
Get the encoded region name for the region this plan is for.
getRegionName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
Get the name of the region.
getRegionName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getRegionName() - Method in class org.apache.hadoop.hbase.RegionTransition
 
getRegionName() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
getRegionName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Gets the region name from the full path node name of an unassigned node.
getRegionNameAsString(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionNameAsString(HRegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionNameAsString() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionNameAsString() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
getRegionNameAsString() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
getRegionNameToRegionInfoMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
Get the regioninfo for a region
getRegionNormalizer(Configuration) - Static method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerFactory
Create a region normalizer from the given conf.
getRegionNormalizerTracker() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getRegionNormalizerZNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getRegionOpeningState(AdminProtos.OpenRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the region opening state from a OpenRegionResponse
getRegionOpeningStateList(AdminProtos.OpenRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Get a list of region opening state from a OpenRegionResponse
getRegionReferenceFileCount(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getRegionReopenPlan(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
getRegionReplicaStoreFileRefreshMultiplier(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
 
getRegionReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Returns the configured replicas per region
getRegionResult(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Gets the result in hbase:meta for the specified region.
getRegions() - Method in class org.apache.hadoop.hbase.client.MultiAction
 
getRegions() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
getRegions() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
getRegions() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
 
getRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional int32 regions = 3;
getRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
optional int32 regions = 3;
getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegions(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
optional int32 regions = 3;
getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegions(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getRegionServer() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager.SinkPeer
 
getRegionServer() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
 
getRegionServer() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
getRegionServer() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
 
getRegionServerAccounting() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRegionServerAccounting() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getRegionServerCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
Return the RegionServer-level coprocessors
getRegionServerFatalLogBuffer() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getRegionServerInfo(ServerName) - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
 
getRegionServerInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.master.HMaster
 
getRegionServerMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRegionServerOfRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
getRegionServerQuotaManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRegionServerQuotaManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get the live region servers
getRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getRegionServers() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
Get a list of all the addresses of all the region servers for this peer cluster
getRegionServerServices() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
 
getRegionServerServices() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
Gets the region server services.
getRegionServerServices() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
Get the RegonServerServices of the server running the transaction or rollback
getRegionServerServices() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
 
getRegionServerServices() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
Get the RegonServerServices of the server running the transaction or rollback
getRegionServerServices() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
 
getRegionServerToRegionMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
Get regionserver to region map
getRegionServerVersion(ServerName) - Method in class org.apache.hadoop.hbase.master.HMaster
 
getRegionServerVersion(ServerName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getRegionServerWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
getRegionsFromMergeQualifier(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Get regions from the merge qualifier of the specified merged region
getRegionsFromMeta(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
getRegionsFromMeta(MasterProcedureEnv, TableName, boolean, boolean) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
getRegionsFromMeta() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
 
getRegionsInRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
This is no longer a public API
getRegionsInRange(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
This is no longer a public API
getRegionsInTransition() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getRegionsInTransition() - Method in class org.apache.hadoop.hbase.master.RegionStates
Get regions in transition and their states
getRegionsInTransitionCount() - Method in class org.apache.hadoop.hbase.master.RegionStates
Get the number of regions in transition.
getRegionsInTransitionInRS() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRegionsInTransitionInRS() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
Get the regions that are currently being opened or closed in the RS
getRegionsInTransitionOrderedByTimestamp() - Method in class org.apache.hadoop.hbase.master.RegionStates
 
getRegionSize(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSizeCalculator
Returns size of given region in bytes.
getRegionSizeMap() - Method in class org.apache.hadoop.hbase.util.RegionSizeCalculator
 
getRegionSizeMB(int) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
Returns the size in MB from the most recent RegionLoad for region
getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionsLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getRegionsMovement(FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
Return how many regions will move per table since their primary RS will change
getRegionsOfTable(TableName) - Method in class org.apache.hadoop.hbase.master.RegionStates
Gets the online regions of the specified table.
getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
getRegionSplitLimit() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
getRegionSplitPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
This gets the class associated with the region split policy which determines when a region split should occur.
getRegionsResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
 
getRegionState(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
getRegionState(String) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
getRegionStates() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
This SHOULD not be public.
getRegionsToAdd() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
Returns the list of new regions added during the on-disk restore.
getRegionsToRemove() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
Returns the list of regions removed during the on-disk restore.
getRegionsToRestore() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
Returns the list of 'restored regions' during the on-disk restore.
getRegionToRegionServerMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
Get region to region server map
getRegionTransitionState(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
Get region transition state
getRegionTransitionState(String) - Method in class org.apache.hadoop.hbase.master.RegionStates
Get region transition state
getRegionWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
getRemaining() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
getRemaining() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
The number of bytes remaining between position and the end of the range.
getRemoteAddress() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
 
getRemoteAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
getRemoteAddress() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
 
getRemoteException(ServiceException) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Return the IOException thrown by the remote server wrapped in ServiceException as cause.
getRemoteIp() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
Returns the remote side ip address when invoked inside an RPC Returns null incase of an error.
getRemotePort() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
getRemoteUser() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
getRenewer() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
 
getReopenStatus(TableName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Used by the client to identify if all regions have the schema updates
getReplicableHFiles(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Get a list of all hfile references in the given peer.
getReplicableHFiles(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
getReplicaCallTimeoutMicroSecondScan() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getReplicaId() - Method in class org.apache.hadoop.hbase.client.Action
 
getReplicaId() - Method in class org.apache.hadoop.hbase.client.Query
Returns region replica id where Query will fetch data from.
getReplicaId() - Method in class org.apache.hadoop.hbase.HRegionInfo
Returns the region replica id
getReplicaId() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
Get the replica id of this region.
getReplicaId() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
Get the replica id of this region.
getReplicaId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
getReplicaId() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
getReplicasToClose() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
getReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getReplicationLag() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getReplicationLoadSink() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
 
getReplicationLoadSink() - Method in class org.apache.hadoop.hbase.ServerLoad
Call directly from client such as hbase shell
getReplicationLoadSourceList() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
 
getReplicationLoadSourceList() - Method in class org.apache.hadoop.hbase.ServerLoad
Call directly from client such as hbase shell
getReplicationManager() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
Get the replication sources manager
getReplicationPeer() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Returns the configured ReplicationPeerConfig for this peerId
getReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
Returns a ReplicationPeerConfig from the znode or null for the given peerId.
getReplicationPeerId() - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
Return the peer id used for replicating to secondary region replicas
getReplicationPeers() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Get the ReplicationPeers used by this ReplicationSourceManager
getReplicationPeers(ZooKeeperWatcher, Configuration, Abortable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
 
getReplicationPeers(ZooKeeperWatcher, Configuration, ReplicationQueuesClient, Abortable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
 
getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
getReplicationQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Retrieves length of the replication queue for metrics.
getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
getReplicationQueues(ZooKeeperWatcher, Configuration, Abortable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
 
getReplicationQueuesClient(ZooKeeperWatcher, Configuration, Abortable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
 
getReplicationSink() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
Get a randomly-chosen replication sink to replicate to.
getReplicationSource(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueues, ReplicationPeers, Server, String, UUID, ReplicationPeerConfig, ReplicationPeer) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Factory method to create a replication source
getReplicationSourceService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getReplicationTracker(ZooKeeperWatcher, ReplicationPeers, Configuration, Abortable, Stoppable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
 
getReplicationZnodesDump(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Returns a string with replication znodes and position of the replication log
getReportTime() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getRequest() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
getRequest() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
 
getRequest() - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
 
getRequest() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
getRequestCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getRequestCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getRequestCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getRequestCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
 
getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getRequestData() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method should return any additional data that is needed on the server side to construct the ColumnInterpreter.
getRequestData() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
This method should return any additional data that is needed on the server side to construct the RowProcessor.
getRequestLog(String) - Static method in class org.apache.hadoop.hbase.http.HttpRequestLog
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
 
getRequests() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
getRequests() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional int64 requests = 4;
getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
optional int64 requests = 4;
getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int64 requests = 3;
getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
optional int64 requests = 3;
getRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
optional int64 requests = 3;
getRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
optional int64 requests = 4;
getRequestsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getRequestSizeBytes() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getRequestsPerSecond() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of requests per second.
getRequestsPerSecond() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getRequestURL() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
Quote the url so that users specifying the HOST HTTP header can't inject attacks.
getRequestUser() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
Returns the user credentials associated with the current RPC request or null if no credentials were provided.
getRequestUser() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
getRequestUser() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
Returns the user credentials associated with the current RPC request or null if no credentials were provided.
getRequestUser() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
getRequestUserName() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
 
getRequestUserName() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
getRequestUserName() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
Returns the username for any user associated with the current RPC request or null if no user is set.
getRescanNode(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
getResource(String) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
 
getResponseBlockSize() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
 
getResponseBlockSize() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
getResponseCellSize() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
The size of response cells that have been accumulated so far.
getResponseCellSize() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
getResponseExceptionSize() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
 
getResponseExceptionSize() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
 
getResponseSizeBytes() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getRestoreDir() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
 
getRestVersion() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
getRESTVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
 
getRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string restVersion = 1;
getRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string restVersion = 1;
getRestVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string restVersion = 1;
getRestVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string restVersion = 1;
getRestVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string restVersion = 1;
getRestVersionBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string restVersion = 1;
getResult() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
getResult(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
getResult() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getResult() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
 
getResult() - Method in interface org.apache.hadoop.hbase.regionserver.Region.FlushResult
 
getResult() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
Obtain the processing result.
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.append_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.atomicIncrement_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.checkAndPut_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.compact_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.createTable_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAll_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRow_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRowTs_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllTs_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteTable_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.disableTable_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.enableTable_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.get_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getColumnDescriptors_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRegionInfo_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRow_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowOrBefore_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRows_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsTs_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumns_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumnsTs_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowTs_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumns_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumnsTs_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableNames_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableRegions_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVer_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVerTs_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.increment_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.incrementRows_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.isTableEnabled_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.majorCompact_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRow_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRows_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowsTs_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowTs_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerClose_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGet_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGetList_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpen_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenTs_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithPrefix_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithScan_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStop_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStopTs_call
 
getResult(I, Hbase.append_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.append
 
getResult(I, Hbase.atomicIncrement_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.atomicIncrement
 
getResult(I, Hbase.checkAndPut_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.checkAndPut
 
getResult(I, Hbase.compact_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.compact
 
getResult(I, Hbase.createTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.createTable
 
getResult(I, Hbase.deleteAll_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAll
 
getResult(I, Hbase.deleteAllRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRow
 
getResult(I, Hbase.deleteAllRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRowTs
 
getResult(I, Hbase.deleteAllTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllTs
 
getResult(I, Hbase.deleteTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteTable
 
getResult(I, Hbase.disableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.disableTable
 
getResult(I, Hbase.enableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.enableTable
 
getResult(I, Hbase.get_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.get
 
getResult(I, Hbase.getColumnDescriptors_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getColumnDescriptors
 
getResult(I, Hbase.getRegionInfo_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRegionInfo
 
getResult(I, Hbase.getRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRow
 
getResult(I, Hbase.getRowOrBefore_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowOrBefore
 
getResult(I, Hbase.getRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRows
 
getResult(I, Hbase.getRowsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsTs
 
getResult(I, Hbase.getRowsWithColumns_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumns
 
getResult(I, Hbase.getRowsWithColumnsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumnsTs
 
getResult(I, Hbase.getRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowTs
 
getResult(I, Hbase.getRowWithColumns_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumns
 
getResult(I, Hbase.getRowWithColumnsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumnsTs
 
getResult(I, Hbase.getTableNames_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableNames
 
getResult(I, Hbase.getTableRegions_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableRegions
 
getResult(I, Hbase.getVer_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVer
 
getResult(I, Hbase.getVerTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVerTs
 
getResult(I, Hbase.increment_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.increment
 
getResult(I, Hbase.incrementRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.incrementRows
 
getResult(I, Hbase.isTableEnabled_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.isTableEnabled
 
getResult(I, Hbase.majorCompact_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.majorCompact
 
getResult(I, Hbase.mutateRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRow
 
getResult(I, Hbase.mutateRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRows
 
getResult(I, Hbase.mutateRowsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowsTs
 
getResult(I, Hbase.mutateRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowTs
 
getResult(I, Hbase.scannerClose_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerClose
 
getResult(I, Hbase.scannerGet_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGet
 
getResult(I, Hbase.scannerGetList_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGetList
 
getResult(I, Hbase.scannerOpen_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpen
 
getResult(I, Hbase.scannerOpenTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenTs
 
getResult(I, Hbase.scannerOpenWithPrefix_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithPrefix
 
getResult(I, Hbase.scannerOpenWithScan_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithScan
 
getResult(I, Hbase.scannerOpenWithStop_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStop
 
getResult(I, Hbase.scannerOpenWithStopTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStopTs
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.append_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndDelete_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndMutate_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndPut_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.closeScanner_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteMultiple_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteSingle_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.exists_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.existsAll_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.get_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getAllRegionLocations_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getMultiple_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getRegionLocation_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerResults_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerRows_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.increment_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.mutateRow_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.openScanner_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.put_call
 
getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.putMultiple_call
 
getResult(I, THBaseService.append_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.append
 
getResult(I, THBaseService.checkAndDelete_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndDelete
 
getResult(I, THBaseService.checkAndMutate_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndMutate
 
getResult(I, THBaseService.checkAndPut_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndPut
 
getResult(I, THBaseService.closeScanner_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.closeScanner
 
getResult(I, THBaseService.deleteMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteMultiple
 
getResult(I, THBaseService.deleteSingle_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteSingle
 
getResult(I, THBaseService.exists_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.exists
 
getResult(I, THBaseService.existsAll_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.existsAll
 
getResult(I, THBaseService.get_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.get
 
getResult(I, THBaseService.getAllRegionLocations_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getAllRegionLocations
 
getResult(I, THBaseService.getMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getMultiple
 
getResult(I, THBaseService.getRegionLocation_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getRegionLocation
 
getResult(I, THBaseService.getScannerResults_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerResults
 
getResult(I, THBaseService.getScannerRows_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerRows
 
getResult(I, THBaseService.increment_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.increment
 
getResult(I, THBaseService.mutateRow_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.mutateRow
 
getResult(I, THBaseService.openScanner_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.openScanner
 
getResult(I, THBaseService.put_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.put
 
getResult(I, THBaseService.putMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.putMultiple
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.append
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.atomicIncrement
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.checkAndPut
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.compact
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.createTable
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAll
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllRow
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllRowTs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllTs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteTable
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.disableTable
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.enableTable
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.get
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getColumnDescriptors
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRegionInfo
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRow
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowOrBefore
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRows
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsTs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsWithColumns
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsWithColumnsTs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowTs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowWithColumns
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowWithColumnsTs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getTableNames
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getTableRegions
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getVer
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getVerTs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.increment
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.incrementRows
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.isTableEnabled
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.majorCompact
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRow
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRows
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRowsTs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRowTs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerClose
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerGet
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerGetList
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpen
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenTs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithPrefix
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithStop
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithStopTs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.append
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndDelete
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndMutate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndPut
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.closeScanner
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.deleteMultiple
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.deleteSingle
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.exists
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.get
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getAllRegionLocations
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getMultiple
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getRegionLocation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getScannerResults
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getScannerRows
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.increment
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.mutateRow
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.openScanner
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.put
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.putMultiple
 
getResultOrProcedure(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
getResults() - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
getResults() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
getResults(ClientProtos.MultiRequest, ClientProtos.MultiResponse, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the results from a protocol buffer MultiResponse
getResults(ClientProtos.MultiRequest, Map<Integer, Integer>, ClientProtos.MultiResponse, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the results from a protocol buffer MultiResponse
getResults(CellScanner, ClientProtos.ScanResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Create Results from the cells using the cells meta data.
getRetainDays() - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
 
getRetCode() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
getRetries() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getRetriesNumber() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getRevision() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the subversion revision number for the root directory
getRitCount() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
 
getRitDuration() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getRoot() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
get/set
getRootBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
getRootBlockDataSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
getRootBlockKey(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
getRootBlockOffset(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
getRootDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
getRootDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRootDir(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getRootDirFileSystem(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getRootIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getRootIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getRootIndexHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getRootIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getRootIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getRootIndexMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 rootIndexSizeKB = 9;
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 rootIndexSizeKB = 9;
getRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 rootIndexSizeKB = 9;
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getRootKeyZNode() - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
getRootProcedureId(Map<Long, Procedure>, Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.Procedure
 
getRow() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
getRow() - Method in class org.apache.hadoop.hbase.client.Cursor
 
getRow() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's row
getRow() - Method in class org.apache.hadoop.hbase.client.Mutation
Method for retrieving the delete's row
getRow() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
getRow() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getRow() - Method in class org.apache.hadoop.hbase.client.Result
Method for retrieving the row key that corresponds to the row from which this Result was created.
getRow(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getRow() - Method in interface org.apache.hadoop.hbase.client.Row
 
getRow() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
getRow() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getRow() - Method in class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
 
getRow() - Method in class org.apache.hadoop.hbase.KeyValue
Deprecated.
getRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes row = 1;
getRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
optional bytes row = 1;
getRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
optional bytes row = 1;
getRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
getRow() - Method in class org.apache.hadoop.hbase.TagRewriteCell
Deprecated.
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
row to increment
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
row key
getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
Row to update
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
key of the row to be completely deleted.
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
key of the row to be completely deleted.
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
Row to update
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
row key
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
row key
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
row key
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
row key
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
row key
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
row key
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
row key
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
row key
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
row key
getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get all the data for the specified table and row at the latest timestamp.
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
row key
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
row key
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
row to check
getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
row to check
getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
row to check
getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
getRowArray() - Method in interface org.apache.hadoop.hbase.Cell
Contiguous raw bytes that may start at any index in the containing array.
getRowArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getRowArray() - Method in class org.apache.hadoop.hbase.KeyValue
 
getRowArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getRowArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getRowBatches() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
list of row batches
getRowBatches() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
list of row batches
getRowBatchesIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
getRowBatchesIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
getRowBatchesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
getRowBatchesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
getRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required uint32 rowBatchSize = 4;
getRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
required uint32 rowBatchSize = 4;
getRowBatchSize() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
required uint32 rowBatchSize = 4;
getRowBufferLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
getRowByte(Cell, int) - Static method in class org.apache.hadoop.hbase.CellUtil
misc
getRowComparator() - Method in class org.apache.hadoop.hbase.TableName
Deprecated.
The comparator is an internal property of the table. Should not have been exposed here
getRowCount(RpcController, ExampleProtos.CountRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.BlockingInterface
 
getRowCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
rpc getRowCount(.hbase.pb.CountRequest) returns (.hbase.pb.CountResponse);
getRowCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.Interface
rpc getRowCount(.hbase.pb.CountRequest) returns (.hbase.pb.CountResponse);
getRowCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.Stub
 
getRowCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
Returns a count of the rows in the region where this coprocessor is loaded.
getRowForRegion(HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
getRowKeyAtOrBefore(GetClosestRowBeforeTracker) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
 
getRowKeyAtOrBefore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getRowKeyAtOrBefore(GetClosestRowBeforeTracker) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Find the key that matches row exactly, or the one that immediately precedes it.
getRowKeyAtOrBefore(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Find the key that matches row exactly, or the one that immediately precedes it.
getRowKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
getRowLength() - Method in interface org.apache.hadoop.hbase.Cell
 
getRowLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getRowLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getRowLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getRowLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getRowLock(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Get an exclusive ( write lock ) lock on a given row.
getRowLock(byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRowLock(byte[], boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Get a row lock for the specified row.
getRowLock(byte[], boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Get a row lock for the specified row.
getRowLockInternal(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRowLockInternal(byte[], boolean, boolean, Region.RowLock) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRowMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
row mutations to execute if the value matches
getRowNum(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
Gives the row count for the given column family and column qualifier, in the given row range as defined in the Scan object.
getRowOffset() - Method in interface org.apache.hadoop.hbase.Cell
 
getRowOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getRowOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getRowOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getRowOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's offset per row per column family (#kvs to be skipped)
getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
Method for retrieving the scan's offset per row per column family (#kvs to be skipped)
getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
Use reversed scan instead.
getRowOrBefore(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
As of version 0.92 this method is deprecated without replacement. Since version 0.96+, you can use reversed scan. getRowOrBefore is used internally to find entries in hbase:meta and makes various assumptions about the table (which are true for hbase:meta but not in general) to be efficient.
getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
Deprecated.
getRowOrBefore(ClientProtos.ClientService.BlockingInterface, byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Deprecated.
since 0.99 - use reversed scanner instead.
getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get the row just before the specified one.
getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Deprecated.
getRowProcessorPB(RowProcessor<S, T>) - Static method in class org.apache.hadoop.hbase.client.coprocessor.RowProcessorClient
 
getRowRanges() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
getRowResource(String, String, String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
 
getRowResourceWithSuffixGlobbing(String, String, String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
 
getRows() - Method in class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
 
getRows() - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
 
getRows(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRows(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRows(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
row keys
getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
row keys
getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
row keys
getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
row keys
getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get all the data for the specified table and rows at the latest timestamp.
getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getRowsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
required uint64 rowsDeleted = 1;
getRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
required uint64 rowsDeleted = 1;
getRowsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
required uint64 rowsDeleted = 1;
getRowsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
getRowsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
getRowsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
getRowsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
getRowsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
getRowsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
getRowsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
getRowsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
getRowsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
getRowsToLock() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
Rows to lock while operation.
getRowString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get all the data for the specified table and rows at the specified timestamp.
getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get the specified columns for the specified table and rows at the latest timestamp.
getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get the specified columns for the specified table and rows at the specified timestamp.
getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getRowTokenizer() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getRowTreeDepth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get all the data for the specified table and row at the specified timestamp.
getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get the specified columns for the specified table and row at the latest timestamp.
getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get the specified columns for the specified table and row at the specified timestamp.
getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getRowWriter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getRPC() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
 
getRPC(boolean) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
 
getRPC() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
Produces a string representation of the method currently being serviced by this Handler.
getRPC(boolean) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
Produces a string representation of the method currently being serviced by this Handler.
getRpcControllerFactory() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getRpcGetRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of rpc get requests to this region server.
getRpcMultiRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of rpc multi requests to this region server.
getRpcMutateRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of rpc mutate requests to this region server.
getRPCPacketLength() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
 
getRPCPacketLength() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
Produces a string representation of the method currently being serviced by this Handler.
getRPCQueueTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
 
getRPCQueueTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
Accesses the queue time for the currently running RPC on the monitored Handler.
getRpcRetryingCallerFactory() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getRpcScanRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of rpc scan requests to this region server.
getRpcServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRpcServer() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
Returns a reference to the region server's RPC server
getRPCStartTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
 
getRPCStartTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
Accesses the start time for the currently running RPC on the monitored Handler.
getRpcTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
getRpcTimeout() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
Deprecated.
getRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Use getReadRpcTimeout or getWriteRpcTimeout instead
getRpcTimeout() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
Deprecated.
getRsCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
Return the RegionServer-level and Region-level coprocessors
getRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Gets RSGroupInfo for the given group name.
getRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
Gets the group information.
getRSGroupInfo(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Gets RSGroupInfo for given group name.
getRSGroupInfo(RpcController, RSGroupAdminProtos.GetRSGroupInfoRequest, RpcCallback<RSGroupAdminProtos.GetRSGroupInfoResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
getRSGroupInfo(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
getRSGroupInfoManager() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
getRSGroupInfoOfServer(RpcController, RSGroupAdminProtos.GetRSGroupInfoOfServerRequest, RpcCallback<RSGroupAdminProtos.GetRSGroupInfoOfServerResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
getRSGroupInfoOfTable(TableName) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Gets RSGroupInfo for the given table's group.
getRSGroupInfoOfTable(RpcController, RSGroupAdminProtos.GetRSGroupInfoOfTableRequest, RpcCallback<RSGroupAdminProtos.GetRSGroupInfoOfTableResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
getRSGroupInfoOfTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
getRSGroupOfServer(Address) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Retrieve the RSGroupInfo a server is affiliated to
getRSGroupOfServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
getRSGroupOfServer(Address) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Gets the group info of server.
getRSGroupOfServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
Gets the group info of server.
getRSGroupOfTable(TableName) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Get the group membership of a table
getRSGroupOfTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
Gets the group name for a given table
getRSRpcServices() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRunnableSet() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
getSampleCount() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
Returns the number of samples kept by the estimator
getSaslProps() - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
 
getSaslQop() - Method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
 
getScan() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getScan() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .hbase.pb.Scan scan = 1;
getScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
required .hbase.pb.Scan scan = 1;
getScan() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
required .hbase.pb.Scan scan = 1;
getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Gets the scan defining the actual details like columns etc.
getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
 
getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns a Scan object from the stored string representation.
getScan() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
Scan instance
getScanBuilder() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .hbase.pb.Scan scan = 1;
getScanDetailsWithId(long) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
getScanForTableName(TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
This method creates a Scan object that will only scan catalog rows that belong to the specified table.
getScanInfo(Store, RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
 
getScanInfo() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getScanInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getScanLabelGenerators(Configuration) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
 
getScanMetrics() - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
Used internally accumulating metrics on scan.
getScanMetrics() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
 
getScanMetrics() - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.
Use ResultScanner.getScanMetrics() instead. And notice that, please do not use this method and ResultScanner.getScanMetrics() together, the metrics will be messed up.
getScanMetrics(ClientProtos.ScanResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
 
getScanner(Scan) - Method in class org.apache.hadoop.hbase.client.HTable
The underlying HTable must not be closed.
getScanner(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
The underlying HTable must not be closed.
getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
The underlying HTable must not be closed.
getScanner(Scan) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
getScanner(byte[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
getScanner(Scan) - Method in interface org.apache.hadoop.hbase.client.Table
Returns a scanner on the current table as specified by the Scan object.
getScanner(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
Gets a scanner on the current table for the given family.
getScanner(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
Gets a scanner on the current table for the given family and qualifier.
getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
 
getScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Create a Scanner on this file.
getScanner(boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getScanner(boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
Create a Scanner on this file.
getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
Create a Scanner on this file.
getScanner() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
 
getScanner(Scan) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getScanner(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getScanner(Scan, NavigableSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getScanner() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
 
getScanner(Scan) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Return an iterator that scans over the HRegion, returning the indicated columns and rows specified by the Scan.
getScanner(Scan, List<KeyValueScanner>) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Return an iterator that scans over the HRegion, returning the indicated columns and rows specified by the Scan.
getScanner(long) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
getScanner(Scan, NavigableSet<byte[]>, long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Return a scanner for both the memstore and the HStore files.
getScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
Deprecated.
Do not write further code which depends on this call. Instead use getStoreFileScanner() which uses the StoreFileScanner class/interface which is the preferred way to scan a store with higher level concepts.
getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
Deprecated.
Do not write further code which depends on this call. Instead use getStoreFileScanner() which uses the StoreFileScanner class/interface which is the preferred way to scan a store with higher level concepts.
getScanner(Scan) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getScanner(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getScanner(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Returns the scanner associated with the specified ID.
getScanner() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.ResultScannerWrapper
 
getScannerCaching() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getScannerCaching() - Method in class org.apache.hadoop.hbase.client.HTable
getScannerCallableForReplica(int) - Method in class org.apache.hadoop.hbase.client.ReversedScannerCallable
 
getScannerCallableForReplica(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getScannerId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
the Id of the Scanner to close *
getScannerId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
the Id of the Scanner to return rows from.
getScannerInstanceResource(String) - Method in class org.apache.hadoop.hbase.rest.ScannerResource
 
getScannerMaxResultSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getScannerOrder() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
MemStoreScanner returns Long.MAX_VALUE because it will always have the latest data among all scanners.
getScannerOrder() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
getScannerOrder() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Get the order of this KeyValueScanner.
getScannerOrder() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
getScannerOrder() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
getScannerOrder() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
getScannerResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
 
getScannerResults(ByteBuffer, TScan, int, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
getScannerResults(ByteBuffer, TScan, int, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
getScannerResults(ByteBuffer, TScan, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
getScannerResults(ByteBuffer, TScan, int) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Get results for the provided TScan object.
getScannerResults(ByteBuffer, TScan, int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
getScannerRows(int, int, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
getScannerRows(int, int, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
getScannerRows(int, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
getScannerRows(int, int) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Grabs multiple rows from a Scanner.
getScannerRows(int, int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
getScanners(long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
 
getScanners(boolean, boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Get all scanners with no filtering based on TTL (that happens further down the line).
getScanners(List<StoreFile>, boolean, boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getScanners(long) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
 
getScanners(boolean, boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Get all scanners with no filtering based on TTL (that happens further down the line).
getScanners(List<StoreFile>, boolean, boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[], long, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Create scanners on the given files and if needed on the memstore with no filtering based on TTL (that happens further down the line).
getScannersForStoreFiles(Collection<StoreFile>, boolean, boolean, long) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
Return an array of scanners corresponding to the given set of store files.
getScannersForStoreFiles(Collection<StoreFile>, boolean, boolean, boolean, boolean, long) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
Return an array of scanners corresponding to the given set of store files.
getScannersForStoreFiles(Collection<StoreFile>, boolean, boolean, boolean, boolean, ScanQueryMatcher, long, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
Return an array of scanners corresponding to the given set of store files, And set the ScanQueryMatcher for each store file scanner for further optimization
getScannersForStoreFiles(Collection<StoreFile>, boolean, boolean, boolean, boolean, ScanQueryMatcher, long) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
getScannersNoCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
Get a filtered list of scanners.
getScannerTimeout() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getScanOrBuilder() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .hbase.pb.Scan scan = 1;
getScanOrBuilder() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
required .hbase.pb.Scan scan = 1;
getScanOrBuilder() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
required .hbase.pb.Scan scan = 1;
getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
getScanQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Retrieves length of the scan queue for metrics when use RWQueueRpcExecutor.
getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
getScanResource(String, int, String, String, List<String>, int, int, long, long, boolean, boolean, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
 
getScans() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Allows subclasses to get the list of Scan objects.
getScanType(CompactionRequest) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.Compactor.InternalScannerFactory
 
getScheduler() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
getScheduler() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
 
getSchemaAlterStatus(RpcController, MasterProtos.GetSchemaAlterStatusRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Get the number of regions of the table that have been updated by the alter.
getSchemaResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
 
getScheme(HttpConfig.Policy) - Method in class org.apache.hadoop.hbase.http.HttpConfig
 
getSchemePrefix() - Method in class org.apache.hadoop.hbase.http.HttpConfig
 
getScope() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getScopes() - Method in class org.apache.hadoop.hbase.wal.WALKey
 
getScopeWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
Returns a WALEntryFilter for checking the scope.
getScopeWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
 
getScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
getSecond() - Method in class org.apache.hadoop.hbase.util.Pair
Return the second element stored in the pair.
getSecond() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
Return the second element stored in the pair.
getSecond() - Method in class org.apache.hadoop.hbase.util.Triple
 
getSecretKeyForSubject(String, Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Resolves a key for the given subject
getSecretManager() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
getSecurityCapabilities() - Method in interface org.apache.hadoop.hbase.client.Admin
Return the set of supported security capabilities.
getSecurityCapabilities() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getSecurityCapabilities(RpcController, MasterProtos.SecurityCapabilitiesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Returns the security capabilities in effect on the cluster
getSelectionTime() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
getSeqid() - Method in class org.apache.hadoop.hbase.executor.EventHandler
 
getSeqNum() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getSeqNumColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the column qualifier for seqNum column for replicaId
getSeqNumDuringOpen(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getSequenceId() - Method in interface org.apache.hadoop.hbase.Cell
A region-specific unique monotonically increasing sequence ID given to each Cell.
getSequenceId() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getSequenceId() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
getSequenceId() - Method in class org.apache.hadoop.hbase.KeyValue
used to achieve atomic operations in the memstore.
getSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Do not change this sequence id.
getSequenceId() - Method in interface org.apache.hadoop.hbase.regionserver.SequenceId
 
getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReplayHLogKey
Returns the original sequence id
getSequenceId() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getSequenceId() - Method in class org.apache.hadoop.hbase.wal.WALKey
Wait for sequence number to be assigned & return the assigned value
getSequenceNumber() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getSerializedLength() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
Returns the length of the ByteBuffer required to serialized the object.
getSerializedLength() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
getSerializer(Class<KeyValue>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
 
getSerializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
 
getSerializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
getServer() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
 
getServer() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
 
getServer() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
getServer() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
Get the Server running the transaction or rollback
getServer() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
 
getServer() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
Get the Server running the transaction or rollback
getServer() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
 
getServerColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the column qualifier for server column for replicaId
getServerCrashProcessingEnabledEvent() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getServerInfo() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 0.92 (HBASE-1502). This will be removed in HBase 2.0.0. Use ClusterStatus.getServers().
getServerInfo(RpcController, AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to get the info of a region server using admin protocol.
getServerInfo(RpcController, AdminProtos.GetServerInfoRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Get some information of the region server.
getServerManager() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getServerManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getServerManager() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getServerManager__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getServerName() - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination.OpenRegionDetails
 
getServerName() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
 
getServerName() - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
 
getServerName() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
getServerName() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getServerName() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
Quote the server name so that users specifying the HOST HTTP header can't inject attacks.
getServerName() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getServerName() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get ServerName
getServerName() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getServerName() - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
getServerName() - Method in interface org.apache.hadoop.hbase.master.procedure.ServerProcedureInterface
 
getServerName() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getServerName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getServerName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get ServerName
getServerName() - Method in class org.apache.hadoop.hbase.RegionTransition
 
getServerName() - Method in interface org.apache.hadoop.hbase.Server
 
getServerName() - Method in class org.apache.hadoop.hbase.ServerName
 
getServerName(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
 
getServerName() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
getServerName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
getServerName() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
getServerName() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
getServerNameAsString() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
getServerNameFromWALDirectoryName(Configuration, String) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
Pulls a ServerName out of a Path generated according to our layout rules.
getServerNameFromWALDirectoryName(Path) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
This function returns region server name from a log file name which is in one of the following formats: hdfs://<name node>/hbase/.logs/<server name>-splitting/... hdfs://<name node>/hbase/.logs/<server name>/...
getServerNameLessStartCode(String) - Static method in class org.apache.hadoop.hbase.ServerName
Utility method to excise the start code from a server name
getServerOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
getServerOperationType() - Method in interface org.apache.hadoop.hbase.master.procedure.ServerProcedureInterface
Given an operation type we can take decisions about what to do with pending operations.
getServerPrincipal() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
 
getServerRegions(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
Get a copy of all regions assigned to a server
getServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getServers() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
 
getServers() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Get list of servers.
getServers() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getServers() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
 
getServers__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getServers__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
 
getServersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getServerStartcodeFromServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
getServerStats(String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Gets the statistics from the given server.
getServerUserRegions(Connection, ServerName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
getServerVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
 
getServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string serverVersion = 4;
getServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string serverVersion = 4;
getServerVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string serverVersion = 4;
getServerVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string serverVersion = 4;
getServerVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string serverVersion = 4;
getServerVersionBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string serverVersion = 4;
getService() - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
 
getService() - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
 
getService() - Method in interface org.apache.hadoop.hbase.coprocessor.CoprocessorService
 
getService() - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
 
getService() - Method in class org.apache.hadoop.hbase.coprocessor.example.RefreshHFilesEndpoint
 
getService() - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
Just returns a reference to this object, which implements the RowCounterService interface.
getService() - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
 
getService() - Method in interface org.apache.hadoop.hbase.coprocessor.SingletonCoprocessorService
 
getService() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
getService() - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
getService() - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
 
getService() - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
 
getService() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
getServiceException(ServiceException) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Return the Exception thrown by the remote server wrapped in ServiceException as cause.
getServiceInterface() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
 
getServiceName() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
getServiceName(Descriptors.ServiceDescriptor) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
Returns the name to use for coprocessor service calls.
getServices() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
getServices() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
getServices() - Method in class org.apache.hadoop.hbase.security.HBasePolicyProvider
 
getSessionId() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
getSessionPasswd() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
getSettingsQualifierForUserNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getSettingsQualifierForUserTable(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getSettingsQualifierRegexForUserNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getSettingsQualifierRegexForUserTable(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getsFromThrift(List<TGet>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
Converts multiple TGets (Thrift) into a list of Gets (HBase).
getSharedData() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
 
getSharedStoreFilePercentage() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
getSharedStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
getShort(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
getShort() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
getShort(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Retrieve the short value at index
getShort() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Retrieve the next short value from this range.
getShortHistogramReport(Histogram) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
 
getShortMidpointKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
Since 0.99.2;
getShortMidpointKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
Don't do any fancy Block Index splitting tricks.
getShortName() - Method in class org.apache.hadoop.hbase.security.User
Returns the shortened version of the user name -- the portion that maps to an operating system user name.
getShortName() - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
 
getShortNameToLog() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getShortTextFormat(Message) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Return short version of Message toString'd, shorter than TextFormat#shortDebugString.
getSimpleName() - Method in enum org.apache.hadoop.hbase.hbtop.field.Size.Unit
 
getSingleSourceSourceByTable() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
getSink() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactory
 
getSink() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl
 
getSinkMetrics() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
Get replication Sink Metrics
getSinksForTesting() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
 
getSize() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
getSize() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
 
getSize() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
Find the size of minimal buffer that could store compressed data.
getSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
 
getSize() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
 
getSize() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Deprecated.
since 0.98.5. Use ImmutableBytesWritable.getLength() instead
getSize() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
getSize() - Method in class org.apache.hadoop.hbase.master.cleaner.DirScanPool
 
getSize() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
getSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
Gets the total size of all StoreFiles in compaction
getSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
 
getSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getSize() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
 
getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.PlainTextMessageBodyProducer
 
getSize(ProtobufMessageHandler, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.ProtobufMessageBodyProducer
 
getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
getSizeOfLogQueue() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Get the sizeOfLogQueue
getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getSizeToCheck(int) - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
 
getSizeToCheck(int) - Method in class org.apache.hadoop.hbase.regionserver.SteppingSplitPolicy
 
getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
 
getSkipReplayedEditsFilter() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
 
getSleepInterval() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
 
getSleepTime() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
 
getSmallCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
getSmallCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getSmallCompactionThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getSmallestReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getSmallQueueInitSize() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
getSnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
 
getSnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
 
getSnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
getSnapshot() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
 
getSnapshotDescription() - Method in exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Deprecated.
since 1.3.0, will be removed in 3.0.0
getSnapshotDescription() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
getSnapshotDescription() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Get the SnapshotDescription
getSnapshotDir() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Get the current snapshot working dir
getSnapshotDirs(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
Retrieve the directories into which snapshots have been restored from (MultiTableSnapshotInputFormatImpl.RESTORE_DIRS_KEY)
getSnapshotList(Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Deprecated.
Returns the list of available snapshots in the specified location
getSnapshotManager() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getSnapshotManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getSnapshotManifest(Configuration, String, Path, FileSystem) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
 
getSnapShotOfAssignment(Collection<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
getSnapshotRootDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Get the snapshot root directory.
getSnapshotsDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
 
getSnapshotsFilesMap(Configuration, AtomicLong, AtomicLong) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Deprecated.
Returns the map of store files based on path for all snapshots
getSnapshotSize() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
 
getSnapshotSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getSnapshotSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Return the size of the snapshot(s) if any
getSnapshotSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
Returns the memstore snapshot size
getSnapshotStats(Configuration, HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Deprecated.
Returns the snapshot stats
getSnapshotStats(Configuration, HBaseProtos.SnapshotDescription, Map<Path, Integer>) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Deprecated.
Returns the snapshot stats
getSnapshotsToScans(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
Retrieve the snapshot name -> list<scan> mapping pushed to configuration by MultiTableSnapshotInputFormatImpl.setSnapshotToScans(org.apache.hadoop.conf.Configuration, java.util.Map)
getSocketAddress() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
getSortedColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
getSortedColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
getSortedColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
getSortedIndexForInsertionId(int) - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
getSortedRanges() - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
get/set
getSortedUniqueTimestamps() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
getSource() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
 
getSource() - Method in class org.apache.hadoop.hbase.master.RegionPlan
Get the source server for the plan for this region.
getSource() - Method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
 
getSource(String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactory
 
getSource(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl
 
getSource(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Get the normal source for a given peer
getSource() - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
getSource() - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
getSourceMetrics() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
getSourceMetrics() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
Get the associated metrics.
getSourceName() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
 
getSources() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Get a list of all the normal sources of this rs
getSplitAlgo(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
 
getSplitCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
 
getSplitEditFilesSorted(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
Returns sorted set of edit files made by splitter, excluding files with '.temp' suffix.
getSplitKey() - Method in class org.apache.hadoop.hbase.io.Reference
 
getSplitKey(byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Deprecated.
getSplitKeysArray(MasterProtos.CreateTableRequest) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
get the split keys in form "byte [][]" from a CreateTableRequest proto
getSplitLogDir(Path, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
getSplitLogDirTmpComponent(String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
getSplitLogManagerCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
Method to retrieve coordination for split log manager
getSplitLogManagerCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
getSplitLogWorkerCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
Method to retrieve coordination for split log worker
getSplitLogWorkerCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
getSplitOrMergeTracker() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getSplitPartSize() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
 
getSplitPlanCount() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getSplitPlanCount() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get the number of region split plans executed.
getSplitPlanCount() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getSplitPoint() - Method in class org.apache.hadoop.hbase.master.normalizer.SplitNormalizationPlan
 
getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
 
getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
 
getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
 
getSplitPoint() - Method in interface org.apache.hadoop.hbase.regionserver.Store
Determines if Store should be split
getSplitPoint() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Gets the split point for the split of this set of store files (approx.
getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getSplitPolicy() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getSplitPolicyClass(HTableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
 
getSplitQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
getSplitQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the size of the split queue
getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Calculates the splits that will serve as input for the map tasks.
getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
 
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
Deprecated.
 
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Calculates the splits that will serve as input for the map tasks.
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
 
getSplits(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Calculates the splits that will serve as input for the map tasks.
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Calculates the splits that will serve as input for the map tasks.
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
 
getSplits(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
 
getSplits(Scan, SnapshotManifest, List<HRegionInfo>, Path, Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
 
getSplits(Scan, SnapshotManifest, List<HRegionInfo>, Path, Configuration, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
 
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
getSplits() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
 
getSplitSize() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
 
getSplitThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
getSplitTransactionCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
Method to retrieve coordination for split transaction.
getSplitTransactionCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
getSrcChecksum() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the checksum of the source files from which Hadoop was compiled.
getStackIndexes() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
getStagingDir(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.JobUtil
Initializes the staging directory and returns the path.
getStagingPath(String, byte[]) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
getStagingPath(Configuration, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
This returns the staging path for a given column family.
getStamp() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getStart() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
 
getStart() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
getStartAndPrefix() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
the prefix (and thus start row) of the keys you want
getStartcode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getStartCode() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get HRegionServer start time
getStartCode() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
getStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int64 startCode = 2;
getStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
optional int64 startCode = 2;
getStartCode() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
optional int64 startCode = 2;
getStartcode() - Method in class org.apache.hadoop.hbase.ServerName
 
getStartCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
getStartCodeColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns the column qualifier for server start code column for replicaId
getStartEndKeys() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
Gets the starting and ending row keys for every region in the currently open table.
getStartEndKeys() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
Since 1.1.0. Use RegionLocator.getStartEndKeys() instead;
getStartEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Gets the starting and ending row keys for every region in the currently open table.
getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
 
getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
 
getStartKey(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Gets the start key from the specified region name.
getStartKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getStartKey() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
getStartKey() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
 
getStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional bytes startKey = 2;
getStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
optional bytes startKey = 2;
getStartKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
optional bytes startKey = 2;
getStartKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
getStartKey() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
getStartKey() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
getStartKey() - Method in interface org.apache.hadoop.hbase.util.KeyRange
 
getStartKeys() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
Gets the starting row key for every region in the currently open table.
getStartKeys() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
Since 1.1.0. Use RegionLocator.getStartEndKeys() instead
getStartKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Gets the starting row key for every region in the currently open table.
getStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
 
getStartRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getStartRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the start row.
getStartRow(int) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
Gets the start row for a given stripe.
getStartRow(int) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getStartRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
getStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bytes startRow = 1;
getStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional bytes startRow = 1;
getStartRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional bytes startRow = 1;
getStartRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
Starting row in table to scan.
getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
Starting row in table to scan.
getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
Starting row in table to scan.
getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Starting row in table to scan.
getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
getStartRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getStarts() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
 
getStartTime() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
getStartTime() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get hbase master start time
getStartTime() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getStartTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
getStartTime() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
getStartTime() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
getStartTime() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
getStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int64 startTime = 5;
getStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int64 startTime = 5;
getStartTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int64 startTime = 5;
getStartTime() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
getState() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getState() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
getState(String) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
 
getState() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
getState(int) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
Convert an ordinal (or state id) to an Enum (or more descriptive) state object.
getState() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
getStateId(MasterProcedureProtos.AddColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
getStateId(MasterProcedureProtos.CreateNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
getStateId(MasterProcedureProtos.CreateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
getStateId(MasterProcedureProtos.DeleteColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
getStateId(MasterProcedureProtos.DeleteNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
getStateId(MasterProcedureProtos.DeleteTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
getStateId(MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
getStateId(MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
getStateId(MasterProcedureProtos.ModifyColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
getStateId(MasterProcedureProtos.ModifyNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
getStateId(MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
getStateId(MasterProcedureProtos.ServerCrashState) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
getStateId(MasterProcedureProtos.TruncateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
getStateId(TState) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
Convert the Enum (or more descriptive) state object to an ordinal (or state id).
getStateTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
getStatisticsTracker() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
getStats() - Method in class org.apache.hadoop.hbase.client.Result
Deprecated.
getStats(ServerName) - Method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
 
getStats() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Get the statistics for this block cache.
getStats() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getStats() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
getStats() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get counter statistics for this cache.
getStats() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
getStats() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEditsReplaySink
Get a string representation of this sink's metrics
getStats() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
Get a string representation of this sink's metrics
getStats() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
getStats() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
Get a string representation of the current statistics for this source
getStats() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Get a string representation of all the sources' metrics
getStatsForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics
 
getStatus() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
Gets the status of this handler; if it is currently servicing an RPC, this status will include the RPC information.
getStatus() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
getStatus() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask.StatusJournalEntry
 
getStatus() - Method in class org.apache.hadoop.hbase.procedure.Procedure
 
getStatusJournal() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
getStatusOfPeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Get the replication status for the specified connected remote slave cluster.
getStatusOfPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getStatusOfPeerFromBackingStore(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Get the replication status for the specified remote slave cluster, which doesn't have to be connected.
getStatusOfPeerFromBackingStore(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getStatusTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
getStd(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
Gives a Pair with first object a List containing Sum and sum of squares, and the second object as row count.
getStealFromQueue() - Method in class org.apache.hadoop.hbase.util.StealJobQueue
Get a queue whose job might be stolen by the consumer of this original queue
getStopper() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
getStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
 
getStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
row to stop scanning on.
getStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
row to stop scanning on.
getStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
getStopRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getStopRowKey() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
getStore() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
getStore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getStore(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Return the Store for the given family
getStoreArchivePath(Configuration, TableName, String, String) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
Get the directory to archive a store directory
getStoreArchivePath(Configuration, HRegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
Get the directory to archive a store directory
getStoreCompactionPriority() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
 
getStoreCompactionPriority() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getStoreCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStoreDir(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Returns the directory path of the specified family
getStoreEngine() - Method in class org.apache.hadoop.hbase.regionserver.HStore
Returns the StoreEngine that is backing this concrete implementation of Store.
getStoreFile(RpcController, AdminProtos.GetStoreFileRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
getStoreFileComparator() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
 
getStoreFileComparator() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getStorefileCount() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Returns the number of files currently in use.
getStorefileCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getStoreFileIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the Size (in bytes) of indexes in storefiles on disk.
getStorefileIndexSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefileIndexSizeMB = 6;
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 storefileIndexSizeMB = 6;
getStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 storefileIndexSizeMB = 6;
getStoreFileInfo(Configuration, FileSystem, HRegionInfo, HRegionInfo, String, Path) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
Returns a StoreFileInfo from the given FileStatus.
getStoreFileList(byte[][]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getStoreFileList(byte[][]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getStoreFileManager() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
getStoreFileOpenAndCloseThreadPool(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getStoreFiles(AdminProtos.AdminService.BlockingInterface, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to get the list of files of a column family on a given region using admin protocol.
getStoreFiles(RpcController, AdminProtos.AdminService.BlockingInterface, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to get the list of files of a column family on a given region using admin protocol.
getStorefiles() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStorefiles() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
 
getStoreFiles(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Returns the store files available for the family.
getStoreFiles(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
 
getStoreFiles(String, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Returns the store files available for the family.
getStorefiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getStorefiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getStorefiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Gets the snapshot of the store files currently in use.
getStorefiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getStorefiles() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
getStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefiles = 3;
getStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 storefiles = 3;
getStorefiles() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 storefiles = 3;
getStorefiles() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStoreFileScanner(boolean, boolean, boolean, long, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
Get a scanner to scan over this StoreFile.
getStorefilesCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getStorefilesCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
getStorefilesIndexSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getStorefilesIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getStoreFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the total size of the store files this region server is serving from.
getStoreFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
Get the total size of the store files this region server is serving from.
getStoreFileSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getStorefileSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefileSizeMB = 4;
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 storefileSizeMB = 4;
getStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 storefileSizeMB = 4;
getStoreFilesLocatedStatus(HRegionFileSystem, String, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Returns the store files' LocatedFileStatus which available for the family.
getStorefilesSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getStoreFilesSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
Get the store file size against this table
getStoreFilesSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
 
getStorefilesSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
getStoreFileTtl() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getStoreFileTtl() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
 
getStoreFlusher() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
getStoreHomedir(Path, HRegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
Deprecated.
getStoreHomedir(Path, String, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
Deprecated.
getStoreOpenAndCloseThreadPool(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getStores() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getStores() - Method in interface org.apache.hadoop.hbase.regionserver.Region
Return the list of Stores managed by this region
getStores() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
getStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 stores = 2;
getStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 stores = 2;
getStores() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 stores = 2;
getStores() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStoreSizeUncompressed() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getStoreSizeUncompressed() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getStoreTracker() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStream(boolean) - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
Get the stream to use.
getStream() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
getStream() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
getStream() - Method in class org.apache.hadoop.hbase.rest.client.Response
Gets the input stream instance.
getStripeBoundaries() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
 
getStripeBoundaries() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getStripeCompactMaxFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
 
getStripeCompactMinFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
 
getStripeCount() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
 
getStripeCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getStripes() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
 
getStripes() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getStructDesc() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
getStructuralString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
getStub() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
getSuccessfulCoalescings() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getSuccessfulCoalescings() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
getSum(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
Gives the sum for a given combination of column qualifier and column family, in the given row range as defined in the Scan object.
getSumHitCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getSumHitCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getSumHitCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getSumHitCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getSummary() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
getSumRequestCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getSumRequestCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getSumRequestCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getSumRequestCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getSuperUsers() - Static method in class org.apache.hadoop.hbase.security.Superusers
 
getSupportedAlgorithms() - Static method in class org.apache.hadoop.hbase.io.compress.Compression
Get names of supported compression algorithms.
getSupportedCiphers() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
Return the set of Ciphers supported by this provider
getSupportedCiphers() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
 
getSupportedCiphers() - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Get names of supported encryption algorithms
getSupportedCiphers(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Get names of supported encryption algorithms
getSupportedCompressionAlgorithms() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Get names of supported compression algorithms.
getSupportedFilters() - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Return a Set of filters supported by the Filter Language
getSwitchZNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getSyncedEntries() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
 
getSyncedPerSec() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
 
getSyncMetrics() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
getSyncWaitMs() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
 
getSystemLoadAverage() - Method in class org.apache.hadoop.hbase.util.JVM
 
getSystemUser() - Static method in class org.apache.hadoop.hbase.security.Superusers
 
getTable() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a Table implementation for accessing a table.
getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.Connection
Retrieve a Table implementation for accessing a table.
getTable(String) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(String, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(byte[], ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
getTable(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Get a reference to the specified table from the pool.
getTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Get a reference to the specified table from the pool.
getTable(TableName) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
Open a table from within the Coprocessor environment
getTable(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
Open a table from within the Coprocessor environment
getTable(TableName) - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getTable(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Gets the table name from the specified region name.
getTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
Get current table name of the region
getTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to get the Table.
getTable() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to get the Table.
getTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the table name.
getTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
getTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
getTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Creates and returns a Table instance from a given table name.
getTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
the table to append the value on
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
to check in and delete from
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
to check in and delete from
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
to check in and put to
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
the table to delete from
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
the table to delete from
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
the table to check on
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
the table to check on
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
the table to get from
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
the table to get from
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
the table to get the Scanner for
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
the table to increment the value on
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
table to apply the mutations
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
the table to get the Scanner for
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
the table to put data in
getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
the table to put data in
getTable(String) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
Caller closes the table afterwards.
getTableAggregate() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
Get a MetricsTableAggregateSource
getTableAggregate() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
 
getTableArchivePath(Path, TableName) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
Get the path to the table archive directory based on the configured archive directory.
getTableArchivePath(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
Get the path to the table archive directory based on the configured archive directory.
getTableCF(ZooKeeperProtos.TableCF[], String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
Get TableCF in TableCFs, if not exist, return null.
getTableCFs() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
Get replicable (table, cf-list) map of this peer
getTableCFs(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Get the table and column-family-list map of the peer.
getTableCFs(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
getTableCFs() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Get replicable (table, cf-list) map of this peer
getTableCFsMap() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
getTableCFsNode(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
getTableCfWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
Returns a WALEntryFilter for checking replication per table and CF.
getTableDesc() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getTableDesc() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getTableDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Method for getting the tableDescriptor
getTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Method for getting the tableDescriptor
getTableDescriptor(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HTable
Gets the table descriptor for this table.
getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
getTableDescriptor() - Method in interface org.apache.hadoop.hbase.client.Table
Gets the table descriptor for this table.
getTableDescriptor() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
 
getTableDescriptor() - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
Gets a TableDescriptor from the masterServices.
getTableDescriptor() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getTableDescriptor() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
getTableDescriptor() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
 
getTableDescriptor() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Get the table descriptor from the Snapshot
getTableDescriptorFromFs(FileSystem, Path, TableName) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Returns the latest table descriptor for the given table directly from the file system if it exists, bypassing the local cache.
getTableDescriptorFromFs(FileSystem, Path, TableName, boolean) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Returns the latest table descriptor for the table located at the given directory directly from the file system if it exists.
getTableDescriptorFromFs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Returns the latest table descriptor for the table located at the given directory directly from the file system if it exists.
getTableDescriptorFromFs(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Returns the latest table descriptor for the table located at the given directory directly from the file system if it exists.
getTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Get tableDescriptors
getTableDescriptors(List<String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get tableDescriptors
getTableDescriptors() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getTableDescriptors(RpcController, MasterProtos.GetTableDescriptorsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Get list of TableDescriptors for requested tables.
getTableDescriptors() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getTableDescriptors() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getTableDescriptors() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
getTableDescriptorsByTableName(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.Admin
Get tableDescriptors
getTableDescriptorsByTableName(List<TableName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get tableDescriptors
getTableDir(Path, byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
getTableDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
 
getTableDir(Path, TableName) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Returns the Path object representing the table directory under path rootdir
getTableDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getTableFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getTableFragmentation(HMaster) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Runs through the HBase rootdir and checks how many stores for each table have more than one file in them.
getTableFragmentation(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Runs through the HBase rootdir and checks how many stores for each table have more than one file in them.
getTableFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTableInfo() - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
 
getTableInfo() - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
getTableInfoPath(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Find the most current table info file for the table located in the given table directory.
getTableLimiter(TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
Returns the limiter associated to the specified table.
getTableLimiter(TableName) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
Return the limiter for the specified table associated with this quota.
getTableList() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
getTableLockManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getTableLockManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getTableLockManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getTableName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getTableName() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use ClientScanner.getTable().
getTableName() - Method in class org.apache.hadoop.hbase.client.HTable
Gets the name of this table.
getTableName() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
Use Table.getName() instead
getTableName() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
getTableName() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
getTableName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use HRegionInfo.getTable(byte[]).
getTableName() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use HRegionInfo.getTable().
getTableName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Get the name of the table
getTableName() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
getTableName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the table name converted to a byte array.
getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
getTableName() - Method in interface org.apache.hadoop.hbase.master.procedure.TableProcedureInterface
 
getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
getTableName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getTableName() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getTableName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
Get the name of the table the region belongs to.
getTableName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getTableName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
getTableName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
getTableName() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getTableName() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getTableName() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
getTableName() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
name of table to create
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
name of table to delete
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
name of the table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
name of the table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
table name
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
name of the table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
name of the table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
table name
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
name of the table to check
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
name of table
getTableName() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
getTableName() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
getTableName(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Returns the TableName object representing the table directory under path rootdir
getTableName() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
getTablename() - Method in class org.apache.hadoop.hbase.wal.WALKey
 
getTableName() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer
 
getTableNameArray(List<TableProtos.TableName>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
getTableNameAsString() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
getTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
getTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
getTableNamePrefix() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
getTableNames() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
getTableNames(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
getTableNames(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
getTableNames() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
getTableNames(RpcController, MasterProtos.GetTableNamesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Get list of userspace table names
getTableNames(AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getTableNames(AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getTableNames() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getTableNames() - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
List all the userspace tables.
getTableNames() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getTableNamespaceManager() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getTableNamespaceManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
getTableOperationType() - Method in interface org.apache.hadoop.hbase.master.procedure.TableProcedureInterface
Given an operation type we can take decisions about what to do with pending operations.
getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
getTablePermissions(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
 
getTableQuota(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTableRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Get the regions of a given table.
getTableRegions(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
get the regions of a given table.
getTableRegions(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getTableRegions(ZooKeeperWatcher, Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Gets all of the regions of the specified table.
getTableRegions(ZooKeeperWatcher, Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Gets all of the regions of the specified table.
getTableRegions(ZooKeeperWatcher, Connection, TableName, boolean, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Gets all of the regions of the specified table.
getTableRegions(ByteBuffer, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getTableRegions(ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getTableRegions(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getTableRegions(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
List the regions associated with a table.
getTableRegions(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getTableRegionsAndLocations(ZooKeeperWatcher, Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
getTableRegionsAndLocations(ZooKeeperWatcher, Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
getTableRegionsAndLocations(ZooKeeperWatcher, Connection, TableName, boolean, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
getTableResource(String) - Method in class org.apache.hadoop.hbase.rest.RootResource
 
getTableRowKey(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTableRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getTables() - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
 
getTables() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Set of tables that are members of this group
getTableSet() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
Get the table set
getTablesInStates(ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
 
getTablesInStates(ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
Gets a list of all the tables set as disabling in zookeeper.
getTableSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
Get the table region size against this table
getTableSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
 
getTablesOnMaster(Configuration) - Static method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
getTableSourceAgg() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
 
getTableStateManager() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
Returns implementation of TableStateManager.
getTableStateManager() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
 
getTableStateManager() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
getTableStateManager() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
getTableStoreFilePathMap(Map<String, Path>, FileSystem, Path, TableName) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Runs through the HBase rootdir/tablename and creates a reverse lookup map for table StoreFile names to the full Path.
getTableStoreFilePathMap(Map<String, Path>, FileSystem, Path, TableName, PathFilter, ExecutorService, HBaseFsck.ErrorReporter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Runs through the HBase rootdir/tablename and creates a reverse lookup map for table StoreFile names to the full Path.
getTableStoreFilePathMap(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Runs through the HBase rootdir and creates a reverse lookup map for table StoreFile names to the full Path.
getTableStoreFilePathMap(FileSystem, Path, PathFilter, ExecutorService, HBaseFsck.ErrorReporter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Runs through the HBase rootdir and creates a reverse lookup map for table StoreFile names to the full Path.
getTableToRegionMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
Get regions for tables
getTableWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
getTableWrapperAgg() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
 
getTag(byte[], int, int, byte) - Static method in class org.apache.hadoop.hbase.Tag
Retrieve the first tag from the tags byte array matching the passed in tag type
getTag(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Get a tag by name
getTagArray(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Returns tag value in a new byte array.
getTagBufferLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
getTagCompressionContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
 
getTagCompressionContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
getTagLength() - Method in class org.apache.hadoop.hbase.Tag
 
getTagOffset(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getTagOffset() - Method in class org.apache.hadoop.hbase.Tag
 
getTags() - Method in class org.apache.hadoop.hbase.KeyValue
Returns any tags embedded in the KeyValue.
getTags() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
getTagsArray() - Method in interface org.apache.hadoop.hbase.Cell
 
getTagsArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getTagsArray() - Method in class org.apache.hadoop.hbase.KeyValue
 
getTagsArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getTagsArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getTagsLength() - Method in interface org.apache.hadoop.hbase.Cell
 
getTagsLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getTagsLength() - Method in class org.apache.hadoop.hbase.KeyValue
This returns the total length of the tag bytes
getTagsLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getTagsLength() - Method in class org.apache.hadoop.hbase.NoTagsKeyValue
 
getTagsLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getTagsOffset() - Method in interface org.apache.hadoop.hbase.Cell
 
getTagsOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getTagsOffset() - Method in class org.apache.hadoop.hbase.KeyValue
This returns the offset where the tag actually starts.
getTagsOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getTagsOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getTagsOffsetWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getTagSorter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getTagWriter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getTailKbParam(HttpServletRequest) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
 
getTailPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the tail of the linked list (most recently used).
getTakingSnapshotLock() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
getTappend() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
the TAppend to append
getTaskMonitor() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
 
getTaskMonitor__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
 
getTaskNode() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
 
getTaskReadySeq() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
Used by unit tests to check how many tasks were processed
getTaskReadySeq() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
 
getTaskReadySeq() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
Returns the number of tasks processed by coordination.
getTasks() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
 
getTasks() - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
Produces a list containing copies of the current state of all non-expired MonitoredTasks handled by this TaskMonitor.
getTdelete() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
the TDelete to execute if the check succeeds
getTdelete() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
the TDelete to delete
getTdeletes() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
list of TDeletes to delete
getTdeletesIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
getTdeletesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
getTempDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
getTerminal() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
getTerminalPrinter(int) - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
getTerminalPrinter(int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
getTerminalPrinter(int) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
 
getTerminalSize() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
getTerminalSize() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
 
getTget() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
the TGet to check for
getTget() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
the TGet to fetch
getTgets() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
a list of TGets to check for
getTgets() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
a list of TGets to fetch, the Result list will have the Results at corresponding positions or null if there was an error
getTgetsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
getTgetsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
getTgetsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
getTgetsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
getThird() - Method in class org.apache.hadoop.hbase.util.Triple
 
getThread() - Method in class org.apache.hadoop.hbase.util.HasThread
 
getThreadCount() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
 
getThreadCount() - Method in class org.apache.hadoop.hbase.master.BulkReOpen
Configuration knobs "hbase.bulk.reopen.threadpool.size" number of regions that can be reopened concurrently.
getThreadInfo(Thread) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
 
getThreadNamePrefix() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
 
getThreadNamePrefix() - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
 
getThreadWakeFrequency() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Interval at which threads should run
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TAppend._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TAppend._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TAuthorization._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TCellVisibility._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionLocation._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TServerName._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
 
getThrottlePoint() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
getThrottlePoint() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
getThroughputControllerClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.CompactionThroughputControllerFactory
 
getThroughputControllerClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.FlushThroughputControllerFactory
 
getTicket() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
getTimeOfDeath(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
Get the time when a server died
getTimeout() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
getTimeout(T) - Method in interface org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue.TimeoutRetriever
 
getTimeoutOnRIT() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
 
getTimeoutOnRIT() - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
 
getTimeRange() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the get's TimeRange
getTimeRange() - Method in class org.apache.hadoop.hbase.client.Increment
Gets the TimeRange used for this increment.
getTimeRange() - Method in class org.apache.hadoop.hbase.client.Scan
 
getTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getTimeRangeTracker() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
 
getTimeRangeTracker(byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
getTimeRemaining() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
getTimestamp() - Method in interface org.apache.hadoop.hbase.Cell
 
getTimestamp() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getTimeStamp() - Method in class org.apache.hadoop.hbase.client.Mutation
Method for retrieving the timestamp
getTimestamp() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
optional uint64 timestamp = 3;
getTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
optional uint64 timestamp = 3;
getTimestamp() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
optional uint64 timestamp = 3;
getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue
 
getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getTimeStamp() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask.StatusJournalEntry
 
getTimestamp() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
getTimestamp() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
 
getTimeStamp() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.JournalEntry
 
getTimeStamp() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl.JournalEntryImpl
 
getTimeStamp() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction.JournalEntry
 
getTimeStamp() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
 
getTimestamp() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
 
getTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional int64 timestamp = 3;
getTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
optional int64 timestamp = 3;
getTimestamp() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
optional int64 timestamp = 3;
getTimestamp() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
getTimestamp() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
timestamp
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
timestamp
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
timestamp
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
timestamp
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
timestamp
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
timestamp
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
timestamp
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
timestamp
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
timestamp
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
getTimestampDeltaWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
get/set
getTimestampEncoder() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getTimestampIndex(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getTimestampIndexWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getTimestampKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
getTimestampOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getTimestampOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getTimeStampOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
Get the TimeStampOfLastAppliedOp.
getTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Get the timeStampsOfLastShippedOp, if there are multiple groups, return the latest one
getTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
getTimestamps() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getTimestamps() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
getTimeStampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
getTimestampString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
getTimeToLive() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getTimeToLive() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
getTimeToPurgeDeletes() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
 
getTimeUnit(T) - Method in interface org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue.TimeoutRetriever
 
getTimeUnit() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
getTimeUnit() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
 
getTimeUnitInMillis() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
 
getTincrement() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
the TIncrement to increment
getToken() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getToken() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getToken(String, String) - Method in class org.apache.hadoop.hbase.security.User
Returns the Token of the specified kind associated with this user, or null if the Token is not present.
getTokenArrayOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getTokenKind() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
 
getTokenLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
get/set
getTokenLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getTokenLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getTokenOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
autogenerated get/set
getTokens() - Method in class org.apache.hadoop.hbase.security.User
Returns all the tokens stored in the user's credentials.
getTopHosts() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
return the sorted list of hosts in terms of their weights
getTopHostsWithWeights() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
return the sorted list of hosts in terms of their weights
getTotalBloomSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getTotalBufferedCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getTotalBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getTotalBytesRead() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
Getter for the number of bytes read from this stream, since creation.
getTotalCompactedSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
 
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getTotalCompactingKvs() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
 
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 totalCompactingKVs = 12;
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int64 totalCompactingKVs = 12;
getTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int64 totalCompactingKVs = 12;
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getTotalCompressedBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
getTotalExpectedRegions() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
 
getTotalFailedCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
getTotalFileSize(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
 
getTotalIncrements() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getTotalIncrements() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getTotalLengthOfArrays(Iterable<byte[]>) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
 
getTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getTotalQueueSize() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getTotalQueueSize() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getTotalRefCount() - Static method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
getTotalRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the total number of requests per second.
getTotalRequestsCount(ClusterStatusProtos.RegionLoad) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
getTotalRequestsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
Get the total number of requests that have been issued against this table
getTotalRequestsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
 
getTotalRowActionRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getTotalSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
getTotalSizeOfCells(Result) - Static method in class org.apache.hadoop.hbase.client.Result
Get total size of raw cells
getTotalSleepTime() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
Getter the total time spent in sleep.
getTotalStaticBloomSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getTotalStaticBloomSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the size (in bytes) of the static bloom filters.
getTotalStaticBloomSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
Returns the total byte size of all Bloom filter bit arrays.
getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 totalStaticBloomSizeKB = 11;
getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 totalStaticBloomSizeKB = 11;
getTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 totalStaticBloomSizeKB = 11;
getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getTotalStaticIndexSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getTotalStaticIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the size (in bytes) of of the static indexes including the roots.
getTotalStaticIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
Returns the total size of all index blocks in the data block indexes, including the root level, intermediate levels, and the leaf level for multi-level indexes, or just the root level for single-level indexes.
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 totalStaticIndexSizeKB = 10;
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 totalStaticIndexSizeKB = 10;
getTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 totalStaticIndexSizeKB = 10;
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getTotalSyncedBytes() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
 
getTotalTableFragmentation(HMaster) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Returns the total overall fragmentation percentage.
getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getTotalUncompressedSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
The total uncompressed size of the root index block, intermediate-level index blocks, and leaf-level index blocks.
getTput() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
the TPut to put if the check succeeds
getTput() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
the TPut to put
getTputs() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
a list of TPuts to commit
getTputsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
getTputsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
getTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
getTrailer() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getTrailer() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getTrailerHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getTrailerHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getTrailerHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getTrailerMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getTrailerMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
getTrailerMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
 
getTrailerSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getTreeBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
getters
getTreeDepth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
getTrowMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
mutations to apply
getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
getTscan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
the scan object to get a Scanner for
getTscan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
the scan object to get a Scanner for
getTTL() - Method in class org.apache.hadoop.hbase.client.Mutation
Return the TTL requested for the result of the mutation, in milliseconds.
getTtl() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
 
getTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional int32 ttl = 3;
getTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional int32 ttl = 3;
getTtl() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional int32 ttl = 3;
getType(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getType() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
 
getType() - Method in class org.apache.hadoop.hbase.KeyValue
Deprecated.
getType() - Method in class org.apache.hadoop.hbase.master.normalizer.EmptyNormalizationPlan
 
getType() - Method in class org.apache.hadoop.hbase.master.normalizer.MergeNormalizationPlan
 
getType() - Method in interface org.apache.hadoop.hbase.master.normalizer.NormalizationPlan
 
getType() - Method in class org.apache.hadoop.hbase.master.normalizer.SplitNormalizationPlan
 
getType() - Method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
getType() - Method in class org.apache.hadoop.hbase.Tag
 
getTypeByte() - Method in interface org.apache.hadoop.hbase.Cell
 
getTypeByte() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getTypeByte() - Method in class org.apache.hadoop.hbase.KeyValue
 
getTypeByte() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getTypeByte() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getTypeBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getTypeFilters() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getTypeString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
getUGI() - Method in class org.apache.hadoop.hbase.security.User
 
getUnblockedFlushCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
getUncaughtExceptionHandler() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
 
getUncaughtExceptionHandler() - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
 
getUnClaimedQueueIds(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Get queueIds from a dead region server, whose queues has not been claimed by other region servers.
getUnClaimedQueueIds(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
getUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getUncompressedSizeWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getUnDeletedHFileRefsQueues() - Method in class org.apache.hadoop.hbase.master.cleaner.ReplicationZKNodeCleaner
 
getUnDeletedQueues() - Method in class org.apache.hadoop.hbase.master.cleaner.ReplicationZKNodeCleaner
 
getUniqueBlocksTotalWeight() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
 
getUniqueFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getUnit() - Method in class org.apache.hadoop.hbase.hbtop.field.Size
 
getUnit(String) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
getUnneededFiles(long, List<StoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
 
getUnneededFiles(long, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
getUnreferencedFiles(Iterable<FileStatus>, SnapshotManager) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
Check to see if any of the passed file names is contained in any of the snapshots.
getUpdatedMaxProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
getUpdatedMinProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
getUpdatesBlockedTime() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the amount of time that updates were blocked.
getUrl() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the subversion URL for the root hbase directory.
getUsage() - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine
 
getUsage() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
 
getUsage() - Method in class org.apache.hadoop.hbase.util.ServerCommandLine
Implementing subclasses should return a usage string to print out.
getUsedBytes() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
getUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getUsedSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
getUser() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
getUser() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
 
getUser() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getUser() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
The user that compiled hbase.
getUserAuths(byte[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
getUserAuths(String) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
 
getUserAuths(byte[], boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
Retrieve the visibility labels for the user.
getUserAuthsAsOrdinals(String) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
Returns the list of ordinals of labels associated with the user
getUserAuthsDataToWriteToZooKeeper(Map<String, List<Integer>>) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
Creates the user auth data to be written to zookeeper.
getUserFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
getUserFromPrincipal(String) - Static method in class org.apache.hadoop.hbase.security.SecurityUtil
Get the user name from a principal
getUserFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserLimiter(UserGroupInformation, TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
Returns the limiter associated to the specified user/table.
getUserName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
getUsername() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to get user's global permissions.
getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, TableName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to get user table permissions.
getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to get permissions for selected namespace.
getUserPermissions(Connection, String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
List all the userPermissions matching the given pattern.
getUserPermissions(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
getUserPermissions(RpcController, AccessControlProtos.GetUserPermissionsRequest, RpcCallback<AccessControlProtos.GetUserPermissionsResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
getUserProvider() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
 
getUserQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserQuota(Connection, String, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserQuota(Connection, String, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserQuotaState(UserGroupInformation) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
Returns the QuotaState associated to the specified user.
getUserRowKey(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
getUserToken() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
 
getUtf8ByteArrays(List<String>) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
getUUIDForCluster(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
Get the UUID for the provided ZK watcher.
getValue() - Method in interface org.apache.hadoop.hbase.Cell
Deprecated.
getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
getValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Get the latest version of the specified column.
getValue() - Method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
 
getValue() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
getValue() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
 
getValue() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
getValue(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getValue(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for accessing the metadata associated with the key
getValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for accessing the metadata associated with the key
getValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
getValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
getValue() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Gets a buffer view to the current value.
getValue() - Method in class org.apache.hadoop.hbase.KeyValue
Deprecated.
getValue() - Method in interface org.apache.hadoop.hbase.metrics.Gauge
 
getValue() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Get the value of this entry.
getValue() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
 
getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string value = 2;
getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
required string value = 2;
getValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
required string value = 2;
getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
required string value = 2;
getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
required string value = 2;
getValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.PropertyOrBuilder
required string value = 2;
getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string value = 2;
getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
required string value = 2;
getValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
required string value = 2;
getValue() - Method in class org.apache.hadoop.hbase.Tag
Returns tag value in a new byte array.
getValue() - Method in class org.apache.hadoop.hbase.TagRewriteCell
Deprecated.
getValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
amount to increment by
getValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
the expected value for the column parameter, if not provided the check is for the non-existence of the column in question
getValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
getValue() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
getValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
getValue() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TCompareOp
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TDeleteType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TDurability
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
the expected value, if not provided the check is for the non-existence of the column in question
getValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
the expected value to be compared against, if not provided the check is for the non-existence of the column in question
getValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
the expected value, if not provided the check is for the non-existence of the column in question
getValueArray() - Method in interface org.apache.hadoop.hbase.Cell
Contiguous raw bytes that may start at any index in the containing array.
getValueArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getValueArray() - Method in class org.apache.hadoop.hbase.KeyValue
 
getValueArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getValueArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getValueAsByteBuffer(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Returns the value wrapped in a new ByteBuffer.
getValueAsByteBuffer(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Returns the value wrapped in a new ByteBuffer.
getValueBufferShallowCopy(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
getValueByteRange() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getValueBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string value = 2;
getValueBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
required string value = 2;
getValueBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
required string value = 2;
getValueBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
required string value = 2;
getValueBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
required string value = 2;
getValueBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.PropertyOrBuilder
required string value = 2;
getValueBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string value = 2;
getValueBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
required string value = 2;
getValueBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
required string value = 2;
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
 
getValueLength() - Method in interface org.apache.hadoop.hbase.Cell
 
getValueLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getValueLength(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getValueLength(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getValueLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getValueLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getValueLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getValueLengthWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getValueOffset() - Method in interface org.apache.hadoop.hbase.Cell
 
getValueOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getValueOffset(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getValueOffset(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
convenience getters
getValueOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getValueOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
getValueOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
getValueOffsetWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Getter for fetching an unmodifiable HTableDescriptor.values map.
getValues(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValues(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValues(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValues() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
getValuesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValuesBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValuesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValuesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValuesCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValueShallowCopy() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
getValueShallowCopy() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
Does a shallow copy of the value at the current position.
getValueShallowCopy() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
getValuesIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
getValuesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValuesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValuesList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValuesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValuesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValuesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValuesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValuesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValuesOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
getValuesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
getValueString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
getValueString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
getValueString() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Convenience method to get a copy of the value as a string - interpreting the bytes as UTF8.
getValueString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get the specified number of versions for the specified table, row, and column.
getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getVer(ByteBuffer, ByteBuffer, byte[], byte[], int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Note: this public interface is slightly different from public Java APIs in regard to handling of the qualifier.
getVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getVersion() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
 
getVersion() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
 
getVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getVersion() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
 
getVersion() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
HRI is no longer a VersionedWritable
getVersion() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
 
getVersion() - Method in class org.apache.hadoop.hbase.security.access.Permission
 
getVersion() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
getVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Verifies current version of file system
getVersion() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the hbase version.
getVersion() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.AcquiredLock
 
getVersion(ZooKeeperWatcher, HRegionInfo) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Get the version of the specified znode
getVersionedBytes() - Method in class org.apache.hadoop.hbase.ServerName
 
getVersionInfo() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
getVersionInfo() - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Get a protocol buffer VersionInfo
getVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
 
getVersionResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
 
getVersionResource() - Method in class org.apache.hadoop.hbase.rest.VersionResource
Dispatch /version/rest to self.
getVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
optional uint64 versionsDeleted = 2;
getVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
optional uint64 versionsDeleted = 2;
getVersionsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
optional uint64 versionsDeleted = 2;
getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get the specified number of versions for the specified table, row, and column.
getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getVerTs(ByteBuffer, ByteBuffer, byte[], byte[], long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Note: this internal interface is slightly different from public APIs in regard to handling of the qualifier.
getVisibilityExpEvaluator(Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
getVisibilityExpEvaluator(Authorizations) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
Creates VisibilityExpEvaluator corresponding to given Authorizations.
getVisibilityExpressionResolver() - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
 
getVisibilityLabelService(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
 
getVisibilityLabelService() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
 
getVLong(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
getVLong() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
getVLong(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Retrieve the long value at index which is stored as VLong
getVLong() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Retrieve the next long value, which is stored as VLong, from this range
getVLongSize(long) - Static method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
getWaitInterval(long, long, long) - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
 
getWaitInterval(long, long, long) - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
 
getWaitInterval() - Method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
getWAL() - Method in interface org.apache.hadoop.hbase.coprocessor.WALCoprocessorEnvironment
 
getWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getWAL(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getWAL(HRegionInfo) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getWAL(byte[], byte[]) - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
 
getWAL(byte[], byte[]) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
getWAL(byte[], byte[]) - Method in class org.apache.hadoop.hbase.wal.WALFactory
 
getWAL(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
 
getWALActionsListener() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSourceService
Returns a WALObserver for the service.
getWALActionsListener() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
getWALArchivePath(Path, Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
getWALArchivePath(Path, Path) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
 
getWALCellCodecClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
 
getWALDir() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
getWALDirectoryName(String) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
Construct the directory name for all WALs on a given server.
getWalEdit(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
 
getWALEntryfilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
Returns a default set of filters
getWALEntryfilter() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
 
getWALEntryfilter() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Returns a WALEntryFilter to use for filtering out WALEntries from the log.
getWALEntryfilter() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
getWALFile() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination.SplitTaskDetails
 
getWALFile() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
 
getWALFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the size of WAL files of this region server.
getWALFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
getWALFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getWALFileSystem(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getWalGroupId() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
 
getWALPrefixFromWALName(String) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
Get prefix of the log from its name, assuming WAL name in format of log_prefix.filenumber.log_suffix @see FSHLog.getCurrentFileName()
getWalProcedureStore() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getWALProvider() - Method in class org.apache.hadoop.hbase.wal.WALFactory
 
getWALRegionDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getWALRegionDir(Configuration, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Returns the WAL region directory based on the region info
getWALRegionDir(Configuration, TableName, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Returns the WAL region directory based on the region info
getWALRootDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
getWALRootDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getWALRootDir(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getWALs() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Get a copy of the wals of the first source on this rs
getWALs() - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
 
getWALs() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
getWALs() - Method in class org.apache.hadoop.hbase.wal.WALFactory
 
getWALs() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
 
getWalsByIdRecoveredQueues() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Get a copy of the wals of the recovered sources on this rs
getWALTableDir(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Returns the Table directory under the WALRootDir for the specified table name
getWarnTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
getWatcher() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
getWatcher() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
 
getWebAppContext() - Method in class org.apache.hadoop.hbase.http.HttpServer
 
getWebAppsPath(String) - Method in class org.apache.hadoop.hbase.http.HttpServer
 
getWebAppsPath(String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer
Get the pathname to the webapps files.
getWeight(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
return the weight for a specific host, that will be the total bytes of all blocks on the host
getWeight() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
 
getWidthUsingPlaceholderForOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
This method is called before blockMeta.qualifierOffsetWidth is known, so we pass in a placeholder.
getWorkerState() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.ReplicationSourceShipperThread
Get the current state of this worker.
getWorkingSnapshotDir(Path, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Get the general working directory for snapshots - where they are built, where they are temporarily copied on export, etc.
getWorkingSnapshotDir(HBaseProtos.SnapshotDescription, Path, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Get the directory to build a snapshot, before it is finalized
getWorkingSnapshotDir(String, Path, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Get the directory to build a snapshot, before it is finalized
getWrapper() - Method in class org.apache.hadoop.hbase.io.MetricsIO
 
getWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
Set bytes into the passed Writable by calling its Writable.readFields(java.io.DataInput).
getWritable(byte[], int, int, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
Set bytes into the passed Writable by calling its Writable.readFields(java.io.DataInput).
getWritableSize() - Method in interface org.apache.hadoop.hbase.io.WritableWithSize
Provide a size hint to the caller.
getWriteAvailable() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
getWriteAvailable() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
 
getWriteAvailable() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
 
getWriteAvailable() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
 
getWriteBuffer() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
Deprecated.
Going away when we drop public support for HTableInterface. Ó
getWriteBuffer() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
since 0.96. This is an internal buffer that should not be read nor write.
getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Returns the maximum size in bytes of the write buffer for this HTable.
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
Returns the maximum size in bytes of the write buffer for this HTable.
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.HTable
Returns the maximum size in bytes of the write buffer for this HTable.
getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
as of 1.0.0. Replaced by BufferedMutator.getWriteBufferSize()
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
as of 1.0.1 (should not have been in 1.0.0). Replaced by BufferedMutator.getWriteBufferSize()
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getWriteEntry() - Method in class org.apache.hadoop.hbase.wal.WALKey
Will block until a write entry has been assigned by they WAL subsystem.
getWriteFailureCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
 
getWriteFailureCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
 
getWriteFailures() - Method in interface org.apache.hadoop.hbase.tool.Canary
 
getWriteFailures() - Method in class org.apache.hadoop.hbase.tool.CanaryTool
 
getWriteFailures() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
 
getWriteFailures() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
 
getWriteLatency() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
 
getWriteLatency() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
getWriteNumber() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntry
 
getWritePoint() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
 
getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
getWriteQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Retrieves length of the write queue for metrics when use RWQueueRpcExecutor.
getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
getWriter() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
getWriterClsNames() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
getWriterClsNames() - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
 
getWriteRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
Get the total number of mutations that have been issued against this region.
getWriteRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
getWriteRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
 
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of write requests to regions hosted on this region server.
getWriteRequestsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
Get the number of write requests that have been issued against this table
getWriteRequestsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
 
getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 writeRequestsCount = 8;
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int64 writeRequestsCount = 8;
getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int64 writeRequestsCount = 8;
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getWriteRequestsRate() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the rate of write requests per second to regions hosted on this region server.
getWriterFactory(Configuration, CacheConfig) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Returns the factory to be used to create HFile writers
getWriterFactoryNoCache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Returns the factory to be used to create HFile writers.
getWriteRpcTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
 
getWriteRpcTimeout() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
getWriteRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
Get timeout (millisecond) of each rpc write request in this Table instance.
getWriteRpcTimeout() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getWriteSuccessCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
 
getWriteSuccessCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
 
getWriteTime() - Method in class org.apache.hadoop.hbase.wal.WALKey
 
getWriteToWAL() - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
getWrittenBytes() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
getWrittenBytes() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
getWrongWALRegionDir(Configuration, TableName, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Deprecated.
For compatibility, will be removed in 4.0.0.
getZkController() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
 
getZKPermissionWatcher() - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
getZKQuorumServersString(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
Return the ZK Quorum servers string given the specified configuration.
getZkw() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
Get the ZK connection to this peer
getZNodeForReplica(int) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get the znode string corresponding to a replicaId
getZnodeParent() - Method in class org.apache.hadoop.hbase.zookeeper.ZKConfig.ZKClusterKey
 
getZnodeVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination.ZkRegionMergeDetails
 
getZnodeVersion() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination.ZkSplitTransactionDetails
 
getZooKeeper() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getZooKeeper() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getZooKeeper() - Method in interface org.apache.hadoop.hbase.Server
Gets the ZooKeeper instance for this server.
getZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
getZooKeeperClusterKey(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
Get the key to the ZK ensemble for this configuration without adding a name at the end
getZooKeeperClusterKey(Configuration, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
Get the key to the ZK ensemble for this configuration and append a name at the end
getZookeeperQuorum() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
Get the Zookeeper Quorum Info
getZookeeperQuorum() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
getZookeeperQuorum() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the Zookeeper Quorum Info
getZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
getZooKeeperWatcher() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
 
global() - Static method in class org.apache.hadoop.hbase.metrics.MetricRegistries
Return the global singleton instance for the MetricRegistries.
GlobalMetricRegistriesAdapter - Class in org.apache.hadoop.hbase.metrics.impl
This class acts as an adapter to export the MetricRegistry's in the global registry.
goToFilterDisplayMode(Screen, Terminal, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
goToInputModeForFilter(Screen, Terminal, int, boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
goToInputModeForRefreshDelay(Screen, Terminal, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
goToMessageMode(Screen, Terminal, int, String) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
grabQuota(long, long, long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
Removes the specified write and read amount from the quota.
grabQuota(long, long, long, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
 
grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to grant a user global permissions.
grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to grant a user table permissions.
grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, String, boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to grant a user namespace permissions.
grant(Connection, TableName, String, byte[], byte[], boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Grants permission on the specified table for the specified user
grant(Connection, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Grants permission on the specified table for the specified user.
grant(Connection, String, String, boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Grants permission on the specified namespace for the specified user.
grant(Connection, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Grants permission on the specified namespace for the specified user.
grant(Connection, String, boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Grant global permissions for the specified user.
grant(Connection, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Grant global permissions for the specified user.
grant(Configuration, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
grant(Configuration, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
grant(Configuration, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
grant(RpcController, AccessControlProtos.GrantRequest, RpcCallback<AccessControlProtos.GrantResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
greater(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
greater(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
GREATER_THAN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
GREATER_THAN Array
GREATER_THAN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
GREATER_THAN_OR_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
GREATER_THAN_OR_EQUAL_TO Array
GREATER_THAN_OR_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
greaterOrEqual(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
greaterOrEqual(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
group(byte[], byte[]) - Method in class org.apache.hadoop.hbase.wal.BoundedGroupingStrategy
 
group(byte[], byte[]) - Method in class org.apache.hadoop.hbase.wal.NamespaceGroupingStrategy
 
group(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.wal.RegionGroupingProvider.RegionGroupingStrategy
Given an identifier and a namespace, pick a group.
GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
JobConf parameter to specify the columns used to produce the key passed to collect from the map phase
GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
JobConf parameter to specify the columns used to produce the key passed to collect from the map phase.
groupHasAccess(String, TableName, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Checks if the user has access to the full table or at least a family/qualifier for the specified action.
GroupingTableMap - Class in org.apache.hadoop.hbase.mapred
Extract grouping columns from input record
GroupingTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.GroupingTableMap
 
GroupingTableMapper - Class in org.apache.hadoop.hbase.mapreduce
Extract grouping columns from input record.
GroupingTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
 
groupOrSplit(Multimap<ByteBuffer, LoadIncrementalHFiles.LoadQueueItem>, LoadIncrementalHFiles.LoadQueueItem, Table, Pair<byte[][], byte[][]>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
Attempt to assign the given load queue item into its target region group.
grow(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
growIfNecessary(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
 
growIfNecessary(int[], int, int) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
 
growIfNecessary(long[], int, int) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
 
GSON - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
GsonUtil - Class in org.apache.hadoop.hbase.util
Helper class for gson.
GZIP - Static variable in class org.apache.hadoop.hbase.util.Base64
Specify that data should be gzip-compressed.
GzipFilter - Class in org.apache.hadoop.hbase.rest.filter
 
GzipFilter() - Constructor for class org.apache.hadoop.hbase.rest.filter.GzipFilter
 
GZIPRequestStream - Class in org.apache.hadoop.hbase.rest.filter
 
GZIPRequestStream(HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
 
GZIPRequestWrapper - Class in org.apache.hadoop.hbase.rest.filter
 
GZIPRequestWrapper(HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
 
GZIPResponseStream - Class in org.apache.hadoop.hbase.rest.filter
 
GZIPResponseStream(HttpServletResponse) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
 
GZIPResponseWrapper - Class in org.apache.hadoop.hbase.rest.filter
 
GZIPResponseWrapper(HttpServletResponse) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 

H

H - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'H'
HalfStoreFileReader - Class in org.apache.hadoop.hbase.io
A facade for a HFile.Reader that serves up either the top or bottom half of a HFile where 'bottom' is the first half of the file containing the keys that sort lowest and 'top' is the second half of the file with keys that sort greater than those of the bottom half.
HalfStoreFileReader(FileSystem, Path, CacheConfig, Reference, Configuration) - Constructor for class org.apache.hadoop.hbase.io.HalfStoreFileReader
Creates a half file reader for a normal hfile.
HalfStoreFileReader(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, Configuration) - Constructor for class org.apache.hadoop.hbase.io.HalfStoreFileReader
Creates a half file reader for a hfile referred to by an hfilelink.
handle(Callback[]) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslDigestCallbackHandler
handle(Callback[]) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslGssCallbackHandler
handleCoprocessorThrowable(CoprocessorEnvironment, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
This is used by coprocessor hooks which are declared to throw IOException (or its subtypes).
handleCorrupted(ProcedureStore.ProcedureIterator) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureLoader
Called by the ProcedureStore.load() in case we have procedures not-ready to be added to the executor, which probably means they are corrupted since some information/link is missing.
handleCreateHdfsRegions(Path, TableName) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
Create the on-disk structure for the table, and returns the regions info.
handleCreateHdfsRegions(Path, TableName) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
Create the on-disk regions, using the tableRootDir provided by the CreateTableHandler.
handleDegenerateRegion(HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling a region that has the same start and end key.
handleDegenerateRegion(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling a region that has the same start and end key.
handleDuplicateStartKeys(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling two regions that have the same start key.
handleDuplicateStartKeys(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling two regions that have the same start key.
handleException(Throwable) - Method in class org.apache.hadoop.hbase.executor.EventHandler
Event exception handler, may be overridden
handleException(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
 
handleHoleInRegionChain(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling a region hole between two keys.
handleHoleInRegionChain(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling a region hole between two keys.
handleHttpInteraction(RestCsrfPreventionFilter.HttpInteraction) - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
Handles an RestCsrfPreventionFilter.HttpInteraction by applying the filtering logic.
handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
 
handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
 
handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
 
handleKeyPress(KeyPress) - Method in interface org.apache.hadoop.hbase.hbtop.screen.ScreenView
 
handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenView
 
handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
 
handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
 
handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
 
handleLockMetadata(String) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Process metadata stored in a ZNode using a callback
handleLockMetadata(String, InterProcessLock.MetadataHandler) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Process metadata stored in a ZNode using a callback object passed to this instance.
handleMetadata(byte[]) - Method in interface org.apache.hadoop.hbase.InterProcessLock.MetadataHandler
Called after lock metadata is successfully read from a distributed lock service.
handleOverlapGroup(Collection<HBaseFsck.HbckInfo>) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling an group of regions that overlap.
handleOverlapGroup(Collection<HBaseFsck.HbckInfo>) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling an group of regions that overlap.
handleOverlapInRegionChain(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling two reigons that overlap in some arbitrary way.
handleOverlapInRegionChain(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling two reigons that overlap in some arbitrary way.
handler - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
 
handlerAdded(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
handlerAdded(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.SaslWrapHandler
 
handleRegionEndKeyNotEmpty(byte[]) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling case where a Table has a last region that does not have an empty end key.
handleRegionEndKeyNotEmpty(byte[]) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling case where a Table has a last region that does not have an empty end key.
handleRegionStartKeyNotEmpty(HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling case where a Table has a first region that does not have an empty start key.
handleRegionStartKeyNotEmpty(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling case where a Table has a first region that does not have an empty start key.
handleRemoteException(Exception) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Like ProtobufUtil.getRemoteException(ServiceException) but more generic, able to handle more than just ServiceException.
handleReportForDutyResponse(RegionServerStatusProtos.RegionServerStartupResponse) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
handleSplit(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling two regions that have the same regionID a specific case of a split
handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
The restore table is executed in place.
handleTimer() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
handleTimer() - Method in interface org.apache.hadoop.hbase.hbtop.screen.ScreenView
 
handleTimer() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
 
handleTimer() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
 
has(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
A convenience method to determine if this object's familyMap contains a value assigned to the given family & qualifier.
has(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Put
A convenience method to determine if this object's familyMap contains a value assigned to the given family, qualifier and timestamp.
has(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
A convenience method to determine if this object's familyMap contains a value assigned to the given family, qualifier and timestamp.
has(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
A convenience method to determine if this object's familyMap contains the given value assigned to the given family, qualifier and timestamp.
has(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Check to see if the Constraint is currently set.
HAS_LARGE_RESULT - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
hasAccess(User, TableName, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
hasAdministratorAccess(ServletContext, HttpServletRequest, HttpServletResponse) - Static method in class org.apache.hadoop.hbase.http.HttpServer
Does the user sending the HttpServletRequest has the administrator ACLs? If it isn't the case, response will be modified to send an error to the user.
hasAttributes() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
hasAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional double averageLoad = 5;
hasAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
optional double averageLoad = 5;
hasAverageLoad() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
optional double averageLoad = 5;
hasBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 batch = 4;
hasBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int32 batch = 4;
hasBatch() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int32 batch = 4;
hasBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
 
hasBypassGlobals() - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
 
hasCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bool cacheBlocks = 11;
hasCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional bool cacheBlocks = 11;
hasCacheBlocks() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional bool cacheBlocks = 11;
hasCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 caching = 9;
hasCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int32 caching = 9;
hasCaching() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int32 caching = 9;
hasCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
hasCallTimeout() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
 
hasCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
hasCellBlockSupport() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
hasCellBlockSupport() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
hasCellBlockSupport() - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
 
hasCellTTL() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
hasCellVisibility() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
hasChildren() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
hasChildren() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
hasClientAckTime() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
hasColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes column = 2;
hasColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
optional bytes column = 2;
hasColumn() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
optional bytes column = 2;
hasColumns() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
hasCompression - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
hasCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
hasCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
hasCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
hasCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string compression = 5;
hasCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional string compression = 5;
hasCompression() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional string compression = 5;
hasCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Check if the table has an attached co-processor represented by the name className
hasCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
required int64 count = 1 [default = 0];
hasCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
required int64 count = 1 [default = 0];
hasCount() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponseOrBuilder
required int64 count = 1 [default = 0];
hasCounter(String) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 currentCompactedKVs = 13;
hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int64 currentCompactedKVs = 13;
hasCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int64 currentCompactedKVs = 13;
hasData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes data = 4;
hasData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
optional bytes data = 4;
hasData() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
optional bytes data = 4;
hasDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .hbase.pb.BulkDeleteRequest.DeleteType deleteType = 2;
hasDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
required .hbase.pb.BulkDeleteRequest.DeleteType deleteType = 2;
hasDeleteType() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
required .hbase.pb.BulkDeleteRequest.DeleteType deleteType = 2;
hasEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional bytes endKey = 3;
hasEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
optional bytes endKey = 3;
hasEndKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
optional bytes endKey = 3;
hasEndRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
hasEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bytes endRow = 2;
hasEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional bytes endRow = 2;
hasEndRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional bytes endRow = 2;
hasEndRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
hasEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int64 endTime = 6;
hasEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int64 endTime = 6;
hasEndTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int64 endTime = 6;
hasError() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
hasException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
 
hasException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
hasException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
hasException() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
hasException() - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
Check if an exception has occurred when re-setting the watch.
hasFamilies() - Method in class org.apache.hadoop.hbase.client.Get
Method for checking if any families have been inserted into this Get
hasFamilies() - Method in class org.apache.hadoop.hbase.client.Increment
Method for checking if any families have been inserted into this Increment
hasFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
 
hasFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Checks to see if this table contains the given column family
hasFamily() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasFamilyStamp - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
hasFan() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
hasFilter() - Method in class org.apache.hadoop.hbase.client.Scan
 
hasFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional string filter = 8;
hasFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional string filter = 8;
hasFilter() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional string filter = 8;
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.Filter
Primarily used to check for conflicts with scans(such as scans that do not read a full row at a time).
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterBase
Fitlers that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
hasFoundKV() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
hasFreeSpace() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
hash - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The hash value for this entries key
hash - Variable in class org.apache.hadoop.hbase.util.AbstractByteRange
Variable for lazy-caching the hashCode of this range.
hash - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Hash Function
Hash - Class in org.apache.hadoop.hbase.util
This class represents a common API for hashing functions.
Hash() - Constructor for class org.apache.hadoop.hbase.util.Hash
 
hash(byte[]) - Method in class org.apache.hadoop.hbase.util.Hash
Calculate a hash using all bytes from the input argument, and a seed of -1.
hash(byte[], int) - Method in class org.apache.hadoop.hbase.util.Hash
Calculate a hash using all bytes from the input argument, and a provided seed value.
hash(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Hash
Calculate a hash using bytes from 0 to length, and the provided seed value
hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.Hash
Calculate a hash using bytes from offset to offset + length, and the provided seed value.
hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.JenkinsHash
taken from hashlittle() -- hash a variable-length key into a 32-bit value
hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.MurmurHash
 
hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.MurmurHash3
Returns the MurmurHash3_x86_32 hash.
hash128(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the MD5 digest of the concatenation of the supplied arguments.
hash128(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the MD5 digest of the concatenation of the supplied arguments.
hash256(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the SHA-256 digest of the concatenation of the supplied arguments.
hash256(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the SHA-256 digest of the concatenation of the supplied arguments.
HASH_NONCE_GRACE_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
 
hashCode(Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
Returns a hash code that is always the same for two Cells having a matching equals(..) result.
hashCode() - Method in class org.apache.hadoop.hbase.client.Action
 
hashCode() - Method in class org.apache.hadoop.hbase.client.Get
 
hashCode() - Method in class org.apache.hadoop.hbase.client.Increment
 
hashCode() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
hashCode() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
hashCode() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
hashCode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
hashCode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
hashCode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
Generated by Eclipse
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
hashCode() - Method in class org.apache.hadoop.hbase.hbtop.field.Size
 
hashCode() - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
hashCode() - Method in class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
 
hashCode() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
hashCode() - Method in class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
 
hashCode() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
hashCode() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.io.FileLink
 
hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
hashCode() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
hashCode() - Method in class org.apache.hadoop.hbase.io.Reference
 
hashCode() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
hashCode(User, String, InetSocketAddress) - Static method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
hashCode() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
hashCode() - Method in class org.apache.hadoop.hbase.KeyValue
In line with KeyValue.equals(Object), only uses the key portion, not the value.
hashCode() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
hashCode() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
hashCode() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
 
hashCode() - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
 
hashCode() - Method in class org.apache.hadoop.hbase.master.RegionPlan
 
hashCode() - Method in class org.apache.hadoop.hbase.master.RegionState
Don't count timestamp in hash code calculation
hashCode() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.net.Address
 
hashCode() - Method in class org.apache.hadoop.hbase.procedure.ProcedureManager
 
hashCode() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns the hash code of the entry by xor'ing the hash values of the key and value of this entry.
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.security.access.Permission
 
hashCode() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hashCode() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
 
hashCode() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
 
hashCode() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
hashCode() - Method in class org.apache.hadoop.hbase.security.User
 
hashCode() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
 
hashCode() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hashCode() - Method in class org.apache.hadoop.hbase.ServerName
 
hashCode() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
hashCode() - Method in class org.apache.hadoop.hbase.TableName
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
 
hashCode() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
hashCode() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
hashCode() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
hashCode() - Method in exception org.apache.hadoop.hbase.thrift.ThriftServerRunner.IOErrorWithCause
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
hashCode() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
hashCode() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
hashCode() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
hashCode() - Method in class org.apache.hadoop.hbase.util.Bytes
 
hashCode(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
hashCode(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
hashCode(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
hashCode() - Method in class org.apache.hadoop.hbase.util.HashedBytes
 
hashCode() - Method in class org.apache.hadoop.hbase.util.ImmutableByteArray
 
hashCode() - Method in class org.apache.hadoop.hbase.util.NonceKey
 
hashCode() - Method in class org.apache.hadoop.hbase.util.Pair
 
hashCode() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
hashCode() - Method in class org.apache.hadoop.hbase.util.Triple
 
hashCode() - Method in class org.apache.hadoop.hbase.wal.WALKey
 
hashCode() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.MutationReplay
 
hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
 
hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.DeleteNodeFailSilent
 
hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
 
hashCode() - Method in class org.apache.hadoop.metrics2.util.MetricQuantile
 
hashCodeIgnoreMvcc(Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
Returns a hash code that is always the same for two Cells having a matching equals(..) result.
hashCount - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Number of hash functions
hasHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int32 heapSizeMB = 4;
hasHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
optional int32 heapSizeMB = 4;
hasHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
optional int32 heapSizeMB = 4;
HashedBytes - Class in org.apache.hadoop.hbase.util
This class encapsulates a byte array and overrides hashCode and equals so that it's identity is based on the data rather than the array instance.
HashedBytes(byte[]) - Constructor for class org.apache.hadoop.hbase.util.HashedBytes
 
hasHigherPriority(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns which operator has higher precedence
HashTable - Class in org.apache.hadoop.hbase.mapreduce
 
HashTable(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.HashTable
 
HashTable.HashMapper - Class in org.apache.hadoop.hbase.mapreduce
 
HashTable.HashMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
 
HashTable.TableHash - Class in org.apache.hadoop.hbase.mapreduce
 
HashTable.TableHash() - Constructor for class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
 
HashTable.TableHash.Reader - Class in org.apache.hadoop.hbase.mapreduce
 
hashType - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Hash type
hashType - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
Hash function type to use, as defined in Hash
hasId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional int64 id = 4;
hasId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
optional int64 id = 4;
hasId() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
optional int64 id = 4;
hasId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
hasInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional bool inMemory = 4;
hasInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
optional bool inMemory = 4;
hasInMemory() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
optional bool inMemory = 4;
hasJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jerseyVersion = 5;
hasJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string jerseyVersion = 5;
hasJerseyVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string jerseyVersion = 5;
hasJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jvmVersion = 2;
hasJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string jvmVersion = 2;
hasJvmVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string jvmVersion = 2;
hasKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
required bytes key = 1;
hasKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
required bytes key = 1;
hasKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
required bytes key = 1;
hasKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
required string key = 1;
hasKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
required string key = 1;
hasKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.PropertyOrBuilder
required string key = 1;
hasLabels() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
hasLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
 
hasLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional string location = 5;
hasLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
optional string location = 5;
hasLocation() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
optional string location = 5;
hasMaster() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Check if there is a master available.
hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int32 maxHeapSizeMB = 5;
hasMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
optional int32 maxHeapSizeMB = 5;
hasMaxHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
optional int32 maxHeapSizeMB = 5;
hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional int32 maxVersions = 4;
hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional int32 maxVersions = 4;
hasMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional int32 maxVersions = 4;
hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 maxVersions = 7;
hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int32 maxVersions = 7;
hasMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int32 maxVersions = 7;
hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 memstoreSizeMB = 5;
hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 memstoreSizeMB = 5;
hasMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 memstoreSizeMB = 5;
hasMetaTableRegion() - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
hasMetaTableRegion() - Method in interface org.apache.hadoop.hbase.master.procedure.ServerProcedureInterface
 
hasMinimumVersion(HBaseProtos.VersionInfo, int, int) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
 
hasMoreFanNodes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
hasMoreValues() - Method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
 
hasMoreValues(ScannerContext.NextState) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
 
hasMVCCInfo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
hasMVCCInfo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
required bytes name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
required bytes name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
required bytes name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
optional string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
optional string name = 1;
hasNamespace() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasNext() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureIterator
Returns true if the iterator has more elements.
hasNext() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
 
hasNext() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
 
hasNext() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
hasNext() - Method in class org.apache.hadoop.hbase.types.StructIterator
 
hasNext() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
 
hasNonce() - Method in class org.apache.hadoop.hbase.client.Action
 
hasNonceGroup() - Method in class org.apache.hadoop.hbase.client.MultiAction
 
hasNullColumn - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
hasNullColumnInQuery() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
hasNullColumnInQuery() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.LegacyScanQueryMatcher
Deprecated.
 
hasNullColumnInQuery() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
hasNullColumnInQuery() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasOccurrences() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
hasOccurrences() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
hasOccurrences() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
hasOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string osVersion = 3;
hasOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string osVersion = 3;
hasOsVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string osVersion = 3;
hasOwner() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
hasParent() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
hasParentId() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
hasPreviousFanNodes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
hasPriority() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
hasProcedureSupport() - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
 
hasQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional bool readOnly = 5;
hasReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
optional bool readOnly = 5;
hasReadOnly() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
optional bool readOnly = 5;
hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 readRequestsCount = 7;
hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int64 readRequestsCount = 7;
hasReadRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int64 readRequestsCount = 7;
hasReferences() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
hasReferences(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Returns true if the specified family has reference files
hasReferences(HTableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Check whether region has Reference file
hasReferences() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
hasReferences() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
hasReferences(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
Determines whether any files in the collection are references.
hasRegionMemstoreReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
hasRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional int32 regions = 3;
hasRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
optional int32 regions = 3;
hasRegions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
optional int32 regions = 3;
hasRegionsToAdd() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
 
hasRegionsToRemove() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
 
hasRegionsToRestore() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
 
hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional int64 requests = 4;
hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
optional int64 requests = 4;
hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int64 requests = 3;
hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
optional int64 requests = 3;
hasRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
optional int64 requests = 3;
hasRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
optional int64 requests = 4;
hasRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string restVersion = 1;
hasRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string restVersion = 1;
hasRestVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string restVersion = 1;
hasResultData() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 rootIndexSizeKB = 9;
hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 rootIndexSizeKB = 9;
hasRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 rootIndexSizeKB = 9;
hasRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
optional bytes row = 1;
hasRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
optional bytes row = 1;
hasRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required uint32 rowBatchSize = 4;
hasRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
required uint32 rowBatchSize = 4;
hasRowBatchSize() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
required uint32 rowBatchSize = 4;
hasRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
required uint64 rowsDeleted = 1;
hasRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
required uint64 rowsDeleted = 1;
hasRowsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
required uint64 rowsDeleted = 1;
hasScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .hbase.pb.Scan scan = 1;
hasScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
required .hbase.pb.Scan scan = 1;
hasScan() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
required .hbase.pb.Scan scan = 1;
hasSelection() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
 
hasServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string serverVersion = 4;
hasServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string serverVersion = 4;
hasServerVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string serverVersion = 4;
hasStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int64 startCode = 2;
hasStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
optional int64 startCode = 2;
hasStartCode() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
optional int64 startCode = 2;
hasStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional bytes startKey = 2;
hasStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
optional bytes startKey = 2;
hasStartKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
optional bytes startKey = 2;
hasStartRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
hasStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bytes startRow = 1;
hasStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional bytes startRow = 1;
hasStartRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional bytes startRow = 1;
hasStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int64 startTime = 5;
hasStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int64 startTime = 5;
hasStartTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int64 startTime = 5;
hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefileIndexSizeMB = 6;
hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 storefileIndexSizeMB = 6;
hasStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 storefileIndexSizeMB = 6;
hasStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefiles = 3;
hasStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 storefiles = 3;
hasStorefiles() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 storefiles = 3;
hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefileSizeMB = 4;
hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 storefileSizeMB = 4;
hasStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 storefileSizeMB = 4;
hasStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 stores = 2;
hasStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 stores = 2;
hasStores() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 stores = 2;
hasTable() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasTagCompression - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
hasTagCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
hasTagCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
hasTagCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
HasThread - Class in org.apache.hadoop.hbase.util
Abstract class which contains a Thread and delegates the common Thread methods to that instance.
HasThread() - Constructor for class org.apache.hadoop.hbase.util.HasThread
 
HasThread(String) - Constructor for class org.apache.hadoop.hbase.util.HasThread
 
hasTimeout() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
optional uint64 timestamp = 3;
hasTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
optional uint64 timestamp = 3;
hasTimestamp() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
optional uint64 timestamp = 3;
hasTimestamp() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional int64 timestamp = 3;
hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
optional int64 timestamp = 3;
hasTimestamp() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
optional int64 timestamp = 3;
hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
hasTooManyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
hasTooManyStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 totalCompactingKVs = 12;
hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int64 totalCompactingKVs = 12;
hasTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int64 totalCompactingKVs = 12;
hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 totalStaticBloomSizeKB = 11;
hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 totalStaticBloomSizeKB = 11;
hasTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 totalStaticBloomSizeKB = 11;
hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 totalStaticIndexSizeKB = 10;
hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 totalStaticIndexSizeKB = 10;
hasTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 totalStaticIndexSizeKB = 10;
hasTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional int32 ttl = 3;
hasTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional int32 ttl = 3;
hasTtl() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional int32 ttl = 3;
hasUnDeletedQueues() - Method in class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
 
hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasUserTimestamp() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
 
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
required string value = 2;
hasValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
required string value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
required string value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
required string value = 2;
hasValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.PropertyOrBuilder
required string value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
required string value = 2;
hasValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
required string value = 2;
hasVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
optional uint64 versionsDeleted = 2;
hasVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
optional uint64 versionsDeleted = 2;
hasVersionsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
optional uint64 versionsDeleted = 2;
hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 writeRequestsCount = 8;
hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int64 writeRequestsCount = 8;
hasWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int64 writeRequestsCount = 8;
havingSystemAuth(byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
Deprecated.
havingSystemAuth(User) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
havingSystemAuth(byte[]) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
havingSystemAuth(User) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
System checks for user auth during admin operations.
Hbase - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase
 
Hbase.append_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.append_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
Hbase.append_args(TAppend) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
Hbase.append_args(Hbase.append_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
Performs a deep copy on other.
Hbase.append_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.append_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.append_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
Hbase.append_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
Hbase.append_result(Hbase.append_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
Performs a deep copy on other.
Hbase.append_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.AsyncClient - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
Hbase.AsyncClient.append_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.append_call(TAppend, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.append_call
 
Hbase.AsyncClient.atomicIncrement_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.atomicIncrement_call(ByteBuffer, ByteBuffer, ByteBuffer, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.atomicIncrement_call
 
Hbase.AsyncClient.checkAndPut_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.checkAndPut_call(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.checkAndPut_call
 
Hbase.AsyncClient.compact_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.compact_call(ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.compact_call
 
Hbase.AsyncClient.createTable_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.createTable_call(ByteBuffer, List<ColumnDescriptor>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.createTable_call
 
Hbase.AsyncClient.deleteAll_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.deleteAll_call(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAll_call
 
Hbase.AsyncClient.deleteAllRow_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.deleteAllRow_call(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRow_call
 
Hbase.AsyncClient.deleteAllRowTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.deleteAllRowTs_call(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRowTs_call
 
Hbase.AsyncClient.deleteAllTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.deleteAllTs_call(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllTs_call
 
Hbase.AsyncClient.deleteTable_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.deleteTable_call(ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteTable_call
 
Hbase.AsyncClient.disableTable_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.disableTable_call(ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.disableTable_call
 
Hbase.AsyncClient.enableTable_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.enableTable_call(ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.enableTable_call
 
Hbase.AsyncClient.Factory - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.Factory
 
Hbase.AsyncClient.get_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.get_call(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.get_call
 
Hbase.AsyncClient.getColumnDescriptors_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getColumnDescriptors_call(ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getColumnDescriptors_call
 
Hbase.AsyncClient.getRegionInfo_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRegionInfo_call(ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRegionInfo_call
 
Hbase.AsyncClient.getRow_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRow_call(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRow_call
 
Hbase.AsyncClient.getRowOrBefore_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowOrBefore_call(ByteBuffer, ByteBuffer, ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowOrBefore_call
 
Hbase.AsyncClient.getRows_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRows_call(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRows_call
 
Hbase.AsyncClient.getRowsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowsTs_call(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsTs_call
 
Hbase.AsyncClient.getRowsWithColumns_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowsWithColumns_call(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumns_call
 
Hbase.AsyncClient.getRowsWithColumnsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowsWithColumnsTs_call(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumnsTs_call
 
Hbase.AsyncClient.getRowTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowTs_call(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowTs_call
 
Hbase.AsyncClient.getRowWithColumns_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowWithColumns_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumns_call
 
Hbase.AsyncClient.getRowWithColumnsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowWithColumnsTs_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumnsTs_call
 
Hbase.AsyncClient.getTableNames_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getTableNames_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableNames_call
 
Hbase.AsyncClient.getTableRegions_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getTableRegions_call(ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableRegions_call
 
Hbase.AsyncClient.getVer_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getVer_call(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVer_call
 
Hbase.AsyncClient.getVerTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getVerTs_call(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVerTs_call
 
Hbase.AsyncClient.increment_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.increment_call(TIncrement, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.increment_call
 
Hbase.AsyncClient.incrementRows_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.incrementRows_call(List<TIncrement>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.incrementRows_call
 
Hbase.AsyncClient.isTableEnabled_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.isTableEnabled_call(ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.isTableEnabled_call
 
Hbase.AsyncClient.majorCompact_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.majorCompact_call(ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.majorCompact_call
 
Hbase.AsyncClient.mutateRow_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.mutateRow_call(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRow_call
 
Hbase.AsyncClient.mutateRows_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.mutateRows_call(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRows_call
 
Hbase.AsyncClient.mutateRowsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.mutateRowsTs_call(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowsTs_call
 
Hbase.AsyncClient.mutateRowTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.mutateRowTs_call(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowTs_call
 
Hbase.AsyncClient.scannerClose_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerClose_call(int, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerClose_call
 
Hbase.AsyncClient.scannerGet_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerGet_call(int, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGet_call
 
Hbase.AsyncClient.scannerGetList_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerGetList_call(int, int, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGetList_call
 
Hbase.AsyncClient.scannerOpen_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerOpen_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpen_call
 
Hbase.AsyncClient.scannerOpenTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerOpenTs_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenTs_call
 
Hbase.AsyncClient.scannerOpenWithPrefix_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerOpenWithPrefix_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithPrefix_call
 
Hbase.AsyncClient.scannerOpenWithScan_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerOpenWithScan_call(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithScan_call
 
Hbase.AsyncClient.scannerOpenWithStop_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerOpenWithStop_call(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStop_call
 
Hbase.AsyncClient.scannerOpenWithStopTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerOpenWithStopTs_call(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStopTs_call
 
Hbase.AsyncIface - Interface in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor(I) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor
 
Hbase.AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor
 
Hbase.AsyncProcessor.append<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.append() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.append
 
Hbase.AsyncProcessor.atomicIncrement<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.atomicIncrement() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.atomicIncrement
 
Hbase.AsyncProcessor.checkAndPut<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.checkAndPut() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.checkAndPut
 
Hbase.AsyncProcessor.compact<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.compact() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.compact
 
Hbase.AsyncProcessor.createTable<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.createTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.createTable
 
Hbase.AsyncProcessor.deleteAll<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.deleteAll() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAll
 
Hbase.AsyncProcessor.deleteAllRow<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.deleteAllRow() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllRow
 
Hbase.AsyncProcessor.deleteAllRowTs<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.deleteAllRowTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllRowTs
 
Hbase.AsyncProcessor.deleteAllTs<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.deleteAllTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllTs
 
Hbase.AsyncProcessor.deleteTable<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.deleteTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteTable
 
Hbase.AsyncProcessor.disableTable<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.disableTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.disableTable
 
Hbase.AsyncProcessor.enableTable<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.enableTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.enableTable
 
Hbase.AsyncProcessor.get<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.get() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.get
 
Hbase.AsyncProcessor.getColumnDescriptors<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getColumnDescriptors() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getColumnDescriptors
 
Hbase.AsyncProcessor.getRegionInfo<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getRegionInfo() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRegionInfo
 
Hbase.AsyncProcessor.getRow<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getRow() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRow
 
Hbase.AsyncProcessor.getRowOrBefore<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getRowOrBefore() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowOrBefore
 
Hbase.AsyncProcessor.getRows<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getRows() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRows
 
Hbase.AsyncProcessor.getRowsTs<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getRowsTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsTs
 
Hbase.AsyncProcessor.getRowsWithColumns<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getRowsWithColumns() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsWithColumns
 
Hbase.AsyncProcessor.getRowsWithColumnsTs<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getRowsWithColumnsTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsWithColumnsTs
 
Hbase.AsyncProcessor.getRowTs<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getRowTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowTs
 
Hbase.AsyncProcessor.getRowWithColumns<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getRowWithColumns() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowWithColumns
 
Hbase.AsyncProcessor.getRowWithColumnsTs<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getRowWithColumnsTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowWithColumnsTs
 
Hbase.AsyncProcessor.getTableNames<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getTableNames() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getTableNames
 
Hbase.AsyncProcessor.getTableRegions<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getTableRegions() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getTableRegions
 
Hbase.AsyncProcessor.getVer<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getVer() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getVer
 
Hbase.AsyncProcessor.getVerTs<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.getVerTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getVerTs
 
Hbase.AsyncProcessor.increment<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.increment() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.increment
 
Hbase.AsyncProcessor.incrementRows<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.incrementRows() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.incrementRows
 
Hbase.AsyncProcessor.isTableEnabled<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.isTableEnabled() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.isTableEnabled
 
Hbase.AsyncProcessor.majorCompact<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.majorCompact() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.majorCompact
 
Hbase.AsyncProcessor.mutateRow<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.mutateRow() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRow
 
Hbase.AsyncProcessor.mutateRows<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.mutateRows() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRows
 
Hbase.AsyncProcessor.mutateRowsTs<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.mutateRowsTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRowsTs
 
Hbase.AsyncProcessor.mutateRowTs<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.mutateRowTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRowTs
 
Hbase.AsyncProcessor.scannerClose<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.scannerClose() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerClose
 
Hbase.AsyncProcessor.scannerGet<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.scannerGet() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerGet
 
Hbase.AsyncProcessor.scannerGetList<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.scannerGetList() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerGetList
 
Hbase.AsyncProcessor.scannerOpen<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.scannerOpen() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpen
 
Hbase.AsyncProcessor.scannerOpenTs<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.scannerOpenTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenTs
 
Hbase.AsyncProcessor.scannerOpenWithPrefix<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.scannerOpenWithPrefix() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithPrefix
 
Hbase.AsyncProcessor.scannerOpenWithScan<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.scannerOpenWithScan() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithScan
 
Hbase.AsyncProcessor.scannerOpenWithStop<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.scannerOpenWithStop() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithStop
 
Hbase.AsyncProcessor.scannerOpenWithStopTs<I extends Hbase.AsyncIface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncProcessor.scannerOpenWithStopTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithStopTs
 
Hbase.atomicIncrement_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.atomicIncrement_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
Hbase.atomicIncrement_args(ByteBuffer, ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
Hbase.atomicIncrement_args(Hbase.atomicIncrement_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
Performs a deep copy on other.
Hbase.atomicIncrement_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.atomicIncrement_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.atomicIncrement_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
Hbase.atomicIncrement_result(long, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
Hbase.atomicIncrement_result(Hbase.atomicIncrement_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
Performs a deep copy on other.
Hbase.atomicIncrement_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.checkAndPut_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.checkAndPut_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
Hbase.checkAndPut_args(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
Hbase.checkAndPut_args(Hbase.checkAndPut_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
Performs a deep copy on other.
Hbase.checkAndPut_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.checkAndPut_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.checkAndPut_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
Hbase.checkAndPut_result(boolean, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
Hbase.checkAndPut_result(Hbase.checkAndPut_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
Performs a deep copy on other.
Hbase.checkAndPut_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.Client - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Client(TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
Hbase.Client(TProtocol, TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
Hbase.Client.Factory - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Client.Factory() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Client.Factory
 
Hbase.compact_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.compact_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
Hbase.compact_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
Hbase.compact_args(Hbase.compact_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
Performs a deep copy on other.
Hbase.compact_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.compact_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.compact_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
Hbase.compact_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
Hbase.compact_result(Hbase.compact_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
Performs a deep copy on other.
Hbase.compact_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.createTable_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.createTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
Hbase.createTable_args(ByteBuffer, List<ColumnDescriptor>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
Hbase.createTable_args(Hbase.createTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
Performs a deep copy on other.
Hbase.createTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.createTable_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.createTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
Hbase.createTable_result(IOError, IllegalArgument, AlreadyExists) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
Hbase.createTable_result(Hbase.createTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
Performs a deep copy on other.
Hbase.createTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAll_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAll_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
Hbase.deleteAll_args(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
Hbase.deleteAll_args(Hbase.deleteAll_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
Performs a deep copy on other.
Hbase.deleteAll_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAll_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAll_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
Hbase.deleteAll_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
Hbase.deleteAll_result(Hbase.deleteAll_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
Performs a deep copy on other.
Hbase.deleteAll_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAllRow_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRow_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
Hbase.deleteAllRow_args(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
Hbase.deleteAllRow_args(Hbase.deleteAllRow_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
Performs a deep copy on other.
Hbase.deleteAllRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAllRow_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRow_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
Hbase.deleteAllRow_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
Hbase.deleteAllRow_result(Hbase.deleteAllRow_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
Performs a deep copy on other.
Hbase.deleteAllRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAllRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRowTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
Hbase.deleteAllRowTs_args(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
Hbase.deleteAllRowTs_args(Hbase.deleteAllRowTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
Performs a deep copy on other.
Hbase.deleteAllRowTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAllRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRowTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
Hbase.deleteAllRowTs_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
Hbase.deleteAllRowTs_result(Hbase.deleteAllRowTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
Performs a deep copy on other.
Hbase.deleteAllRowTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAllTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
Hbase.deleteAllTs_args(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
Hbase.deleteAllTs_args(Hbase.deleteAllTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
Performs a deep copy on other.
Hbase.deleteAllTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAllTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
Hbase.deleteAllTs_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
Hbase.deleteAllTs_result(Hbase.deleteAllTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
Performs a deep copy on other.
Hbase.deleteAllTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteTable_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
Hbase.deleteTable_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
Hbase.deleteTable_args(Hbase.deleteTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
Performs a deep copy on other.
Hbase.deleteTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteTable_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
Hbase.deleteTable_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
Hbase.deleteTable_result(Hbase.deleteTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
Performs a deep copy on other.
Hbase.deleteTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.disableTable_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.disableTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
Hbase.disableTable_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
Hbase.disableTable_args(Hbase.disableTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
Performs a deep copy on other.
Hbase.disableTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.disableTable_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.disableTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
Hbase.disableTable_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
Hbase.disableTable_result(Hbase.disableTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
Performs a deep copy on other.
Hbase.disableTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.enableTable_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.enableTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
Hbase.enableTable_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
Hbase.enableTable_args(Hbase.enableTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
Performs a deep copy on other.
Hbase.enableTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.enableTable_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.enableTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
Hbase.enableTable_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
Hbase.enableTable_result(Hbase.enableTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
Performs a deep copy on other.
Hbase.enableTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.get_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.get_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
Hbase.get_args(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
Hbase.get_args(Hbase.get_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
Performs a deep copy on other.
Hbase.get_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.get_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.get_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
Hbase.get_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
Hbase.get_result(Hbase.get_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
Performs a deep copy on other.
Hbase.get_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getColumnDescriptors_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getColumnDescriptors_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
Hbase.getColumnDescriptors_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
Hbase.getColumnDescriptors_args(Hbase.getColumnDescriptors_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
Performs a deep copy on other.
Hbase.getColumnDescriptors_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getColumnDescriptors_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getColumnDescriptors_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
Hbase.getColumnDescriptors_result(Map<ByteBuffer, ColumnDescriptor>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
Hbase.getColumnDescriptors_result(Hbase.getColumnDescriptors_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
Performs a deep copy on other.
Hbase.getColumnDescriptors_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRegionInfo_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRegionInfo_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
Hbase.getRegionInfo_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
Hbase.getRegionInfo_args(Hbase.getRegionInfo_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
Performs a deep copy on other.
Hbase.getRegionInfo_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRegionInfo_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRegionInfo_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
Hbase.getRegionInfo_result(TRegionInfo, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
Hbase.getRegionInfo_result(Hbase.getRegionInfo_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
Performs a deep copy on other.
Hbase.getRegionInfo_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRow_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRow_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
Hbase.getRow_args(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
Hbase.getRow_args(Hbase.getRow_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
Performs a deep copy on other.
Hbase.getRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRow_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRow_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
Hbase.getRow_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
Hbase.getRow_result(Hbase.getRow_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
Performs a deep copy on other.
Hbase.getRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowOrBefore_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowOrBefore_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
Hbase.getRowOrBefore_args(ByteBuffer, ByteBuffer, ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
Hbase.getRowOrBefore_args(Hbase.getRowOrBefore_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
Performs a deep copy on other.
Hbase.getRowOrBefore_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowOrBefore_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowOrBefore_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
Hbase.getRowOrBefore_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
Hbase.getRowOrBefore_result(Hbase.getRowOrBefore_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
Performs a deep copy on other.
Hbase.getRowOrBefore_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRows_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRows_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
Hbase.getRows_args(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
Hbase.getRows_args(Hbase.getRows_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
Performs a deep copy on other.
Hbase.getRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRows_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRows_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
Hbase.getRows_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
Hbase.getRows_result(Hbase.getRows_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
Performs a deep copy on other.
Hbase.getRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
Hbase.getRowsTs_args(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
Hbase.getRowsTs_args(Hbase.getRowsTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
Performs a deep copy on other.
Hbase.getRowsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
Hbase.getRowsTs_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
Hbase.getRowsTs_result(Hbase.getRowsTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
Performs a deep copy on other.
Hbase.getRowsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowsWithColumns_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowsWithColumns_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
Hbase.getRowsWithColumns_args(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
Hbase.getRowsWithColumns_args(Hbase.getRowsWithColumns_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
Performs a deep copy on other.
Hbase.getRowsWithColumns_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowsWithColumns_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowsWithColumns_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
Hbase.getRowsWithColumns_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
Hbase.getRowsWithColumns_result(Hbase.getRowsWithColumns_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
Performs a deep copy on other.
Hbase.getRowsWithColumns_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowsWithColumnsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowsWithColumnsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
Hbase.getRowsWithColumnsTs_args(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
Hbase.getRowsWithColumnsTs_args(Hbase.getRowsWithColumnsTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
Performs a deep copy on other.
Hbase.getRowsWithColumnsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowsWithColumnsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowsWithColumnsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
Hbase.getRowsWithColumnsTs_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
Hbase.getRowsWithColumnsTs_result(Hbase.getRowsWithColumnsTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
Performs a deep copy on other.
Hbase.getRowsWithColumnsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
Hbase.getRowTs_args(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
Hbase.getRowTs_args(Hbase.getRowTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
Performs a deep copy on other.
Hbase.getRowTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
Hbase.getRowTs_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
Hbase.getRowTs_result(Hbase.getRowTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
Performs a deep copy on other.
Hbase.getRowTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowWithColumns_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumns_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
Hbase.getRowWithColumns_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
Hbase.getRowWithColumns_args(Hbase.getRowWithColumns_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
Performs a deep copy on other.
Hbase.getRowWithColumns_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowWithColumns_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumns_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
Hbase.getRowWithColumns_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
Hbase.getRowWithColumns_result(Hbase.getRowWithColumns_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
Performs a deep copy on other.
Hbase.getRowWithColumns_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowWithColumnsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumnsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
Hbase.getRowWithColumnsTs_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
Hbase.getRowWithColumnsTs_args(Hbase.getRowWithColumnsTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
Performs a deep copy on other.
Hbase.getRowWithColumnsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowWithColumnsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumnsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
Hbase.getRowWithColumnsTs_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
Hbase.getRowWithColumnsTs_result(Hbase.getRowWithColumnsTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
Performs a deep copy on other.
Hbase.getRowWithColumnsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getTableNames_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableNames_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
Hbase.getTableNames_args(Hbase.getTableNames_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
Performs a deep copy on other.
Hbase.getTableNames_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getTableNames_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableNames_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
Hbase.getTableNames_result(List<ByteBuffer>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
Hbase.getTableNames_result(Hbase.getTableNames_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
Performs a deep copy on other.
Hbase.getTableNames_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getTableRegions_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableRegions_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
Hbase.getTableRegions_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
Hbase.getTableRegions_args(Hbase.getTableRegions_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
Performs a deep copy on other.
Hbase.getTableRegions_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getTableRegions_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableRegions_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
Hbase.getTableRegions_result(List<TRegionInfo>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
Hbase.getTableRegions_result(Hbase.getTableRegions_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
Performs a deep copy on other.
Hbase.getTableRegions_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getVer_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVer_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
Hbase.getVer_args(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
Hbase.getVer_args(Hbase.getVer_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
Performs a deep copy on other.
Hbase.getVer_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getVer_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVer_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
Hbase.getVer_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
Hbase.getVer_result(Hbase.getVer_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
Performs a deep copy on other.
Hbase.getVer_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getVerTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVerTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
Hbase.getVerTs_args(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
Hbase.getVerTs_args(Hbase.getVerTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
Performs a deep copy on other.
Hbase.getVerTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getVerTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVerTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
Hbase.getVerTs_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
Hbase.getVerTs_result(Hbase.getVerTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
Performs a deep copy on other.
Hbase.getVerTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.Iface - Interface in org.apache.hadoop.hbase.thrift.generated
 
Hbase.increment_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.increment_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
Hbase.increment_args(TIncrement) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
Hbase.increment_args(Hbase.increment_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
Performs a deep copy on other.
Hbase.increment_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.increment_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.increment_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
Hbase.increment_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
Hbase.increment_result(Hbase.increment_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
Performs a deep copy on other.
Hbase.increment_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.incrementRows_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.incrementRows_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
Hbase.incrementRows_args(List<TIncrement>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
Hbase.incrementRows_args(Hbase.incrementRows_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
Performs a deep copy on other.
Hbase.incrementRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.incrementRows_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.incrementRows_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
Hbase.incrementRows_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
Hbase.incrementRows_result(Hbase.incrementRows_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
Performs a deep copy on other.
Hbase.incrementRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.isTableEnabled_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.isTableEnabled_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
Hbase.isTableEnabled_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
Hbase.isTableEnabled_args(Hbase.isTableEnabled_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
Performs a deep copy on other.
Hbase.isTableEnabled_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.isTableEnabled_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.isTableEnabled_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
Hbase.isTableEnabled_result(boolean, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
Hbase.isTableEnabled_result(Hbase.isTableEnabled_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
Performs a deep copy on other.
Hbase.isTableEnabled_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.majorCompact_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.majorCompact_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
Hbase.majorCompact_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
Hbase.majorCompact_args(Hbase.majorCompact_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
Performs a deep copy on other.
Hbase.majorCompact_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.majorCompact_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.majorCompact_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
Hbase.majorCompact_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
Hbase.majorCompact_result(Hbase.majorCompact_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
Performs a deep copy on other.
Hbase.majorCompact_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRow_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRow_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
Hbase.mutateRow_args(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
Hbase.mutateRow_args(Hbase.mutateRow_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
Performs a deep copy on other.
Hbase.mutateRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRow_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRow_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
Hbase.mutateRow_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
Hbase.mutateRow_result(Hbase.mutateRow_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
Performs a deep copy on other.
Hbase.mutateRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRows_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRows_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
Hbase.mutateRows_args(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
Hbase.mutateRows_args(Hbase.mutateRows_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
Performs a deep copy on other.
Hbase.mutateRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRows_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRows_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
Hbase.mutateRows_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
Hbase.mutateRows_result(Hbase.mutateRows_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
Performs a deep copy on other.
Hbase.mutateRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRowsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
Hbase.mutateRowsTs_args(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
Hbase.mutateRowsTs_args(Hbase.mutateRowsTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
Performs a deep copy on other.
Hbase.mutateRowsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRowsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
Hbase.mutateRowsTs_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
Hbase.mutateRowsTs_result(Hbase.mutateRowsTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
Performs a deep copy on other.
Hbase.mutateRowsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
Hbase.mutateRowTs_args(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
Hbase.mutateRowTs_args(Hbase.mutateRowTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
Performs a deep copy on other.
Hbase.mutateRowTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
Hbase.mutateRowTs_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
Hbase.mutateRowTs_result(Hbase.mutateRowTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
Performs a deep copy on other.
Hbase.mutateRowTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.Processor<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor(I) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor
 
Hbase.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor
 
Hbase.Processor.append<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.append() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.append
 
Hbase.Processor.atomicIncrement<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.atomicIncrement() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.atomicIncrement
 
Hbase.Processor.checkAndPut<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.checkAndPut() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.checkAndPut
 
Hbase.Processor.compact<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.compact() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.compact
 
Hbase.Processor.createTable<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.createTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.createTable
 
Hbase.Processor.deleteAll<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.deleteAll() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAll
 
Hbase.Processor.deleteAllRow<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.deleteAllRow() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRow
 
Hbase.Processor.deleteAllRowTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.deleteAllRowTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRowTs
 
Hbase.Processor.deleteAllTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.deleteAllTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllTs
 
Hbase.Processor.deleteTable<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.deleteTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteTable
 
Hbase.Processor.disableTable<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.disableTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.disableTable
 
Hbase.Processor.enableTable<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.enableTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.enableTable
 
Hbase.Processor.get<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.get() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.get
 
Hbase.Processor.getColumnDescriptors<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getColumnDescriptors() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getColumnDescriptors
 
Hbase.Processor.getRegionInfo<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRegionInfo() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRegionInfo
 
Hbase.Processor.getRow<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRow() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRow
 
Hbase.Processor.getRowOrBefore<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowOrBefore() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowOrBefore
 
Hbase.Processor.getRows<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRows() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRows
 
Hbase.Processor.getRowsTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowsTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsTs
 
Hbase.Processor.getRowsWithColumns<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowsWithColumns() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumns
 
Hbase.Processor.getRowsWithColumnsTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowsWithColumnsTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumnsTs
 
Hbase.Processor.getRowTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowTs
 
Hbase.Processor.getRowWithColumns<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowWithColumns() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumns
 
Hbase.Processor.getRowWithColumnsTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowWithColumnsTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumnsTs
 
Hbase.Processor.getTableNames<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getTableNames() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableNames
 
Hbase.Processor.getTableRegions<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getTableRegions() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableRegions
 
Hbase.Processor.getVer<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getVer() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVer
 
Hbase.Processor.getVerTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getVerTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVerTs
 
Hbase.Processor.increment<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.increment() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.increment
 
Hbase.Processor.incrementRows<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.incrementRows() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.incrementRows
 
Hbase.Processor.isTableEnabled<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.isTableEnabled() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.isTableEnabled
 
Hbase.Processor.majorCompact<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.majorCompact() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.majorCompact
 
Hbase.Processor.mutateRow<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.mutateRow() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRow
 
Hbase.Processor.mutateRows<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.mutateRows() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRows
 
Hbase.Processor.mutateRowsTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.mutateRowsTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowsTs
 
Hbase.Processor.mutateRowTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.mutateRowTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowTs
 
Hbase.Processor.scannerClose<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerClose() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerClose
 
Hbase.Processor.scannerGet<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerGet() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGet
 
Hbase.Processor.scannerGetList<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerGetList() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGetList
 
Hbase.Processor.scannerOpen<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerOpen() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpen
 
Hbase.Processor.scannerOpenTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerOpenTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenTs
 
Hbase.Processor.scannerOpenWithPrefix<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerOpenWithPrefix() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithPrefix
 
Hbase.Processor.scannerOpenWithScan<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerOpenWithScan() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithScan
 
Hbase.Processor.scannerOpenWithStop<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerOpenWithStop() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStop
 
Hbase.Processor.scannerOpenWithStopTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerOpenWithStopTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStopTs
 
Hbase.scannerClose_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerClose_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
Hbase.scannerClose_args(int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
Hbase.scannerClose_args(Hbase.scannerClose_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
Performs a deep copy on other.
Hbase.scannerClose_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerClose_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerClose_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
Hbase.scannerClose_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
Hbase.scannerClose_result(Hbase.scannerClose_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
Performs a deep copy on other.
Hbase.scannerClose_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerGet_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerGet_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
Hbase.scannerGet_args(int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
Hbase.scannerGet_args(Hbase.scannerGet_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
Performs a deep copy on other.
Hbase.scannerGet_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerGet_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerGet_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
Hbase.scannerGet_result(List<TRowResult>, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
Hbase.scannerGet_result(Hbase.scannerGet_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
Performs a deep copy on other.
Hbase.scannerGet_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerGetList_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerGetList_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
Hbase.scannerGetList_args(int, int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
Hbase.scannerGetList_args(Hbase.scannerGetList_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
Performs a deep copy on other.
Hbase.scannerGetList_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerGetList_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerGetList_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
Hbase.scannerGetList_result(List<TRowResult>, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
Hbase.scannerGetList_result(Hbase.scannerGetList_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
Performs a deep copy on other.
Hbase.scannerGetList_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpen_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpen_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
Hbase.scannerOpen_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
Hbase.scannerOpen_args(Hbase.scannerOpen_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
Performs a deep copy on other.
Hbase.scannerOpen_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpen_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpen_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
Hbase.scannerOpen_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
Hbase.scannerOpen_result(Hbase.scannerOpen_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
Performs a deep copy on other.
Hbase.scannerOpen_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
Hbase.scannerOpenTs_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
Hbase.scannerOpenTs_args(Hbase.scannerOpenTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
Performs a deep copy on other.
Hbase.scannerOpenTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
Hbase.scannerOpenTs_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
Hbase.scannerOpenTs_result(Hbase.scannerOpenTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
Performs a deep copy on other.
Hbase.scannerOpenTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithPrefix_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithPrefix_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
Hbase.scannerOpenWithPrefix_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
Hbase.scannerOpenWithPrefix_args(Hbase.scannerOpenWithPrefix_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
Performs a deep copy on other.
Hbase.scannerOpenWithPrefix_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithPrefix_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithPrefix_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
Hbase.scannerOpenWithPrefix_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
Hbase.scannerOpenWithPrefix_result(Hbase.scannerOpenWithPrefix_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
Performs a deep copy on other.
Hbase.scannerOpenWithPrefix_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithScan_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithScan_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
Hbase.scannerOpenWithScan_args(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
Hbase.scannerOpenWithScan_args(Hbase.scannerOpenWithScan_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
Performs a deep copy on other.
Hbase.scannerOpenWithScan_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithScan_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithScan_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
Hbase.scannerOpenWithScan_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
Hbase.scannerOpenWithScan_result(Hbase.scannerOpenWithScan_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
Performs a deep copy on other.
Hbase.scannerOpenWithScan_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithStop_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStop_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
Hbase.scannerOpenWithStop_args(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
Hbase.scannerOpenWithStop_args(Hbase.scannerOpenWithStop_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
Performs a deep copy on other.
Hbase.scannerOpenWithStop_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithStop_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStop_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
Hbase.scannerOpenWithStop_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
Hbase.scannerOpenWithStop_result(Hbase.scannerOpenWithStop_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
Performs a deep copy on other.
Hbase.scannerOpenWithStop_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithStopTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStopTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
Hbase.scannerOpenWithStopTs_args(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
Hbase.scannerOpenWithStopTs_args(Hbase.scannerOpenWithStopTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Performs a deep copy on other.
Hbase.scannerOpenWithStopTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithStopTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStopTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
Hbase.scannerOpenWithStopTs_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
Hbase.scannerOpenWithStopTs_result(Hbase.scannerOpenWithStopTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
Performs a deep copy on other.
Hbase.scannerOpenWithStopTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HBASE_BALANCER_MAX_BALANCING - Static variable in class org.apache.hadoop.hbase.HConstants
Config for the max balancing time
HBASE_BALANCER_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Config for the balancer period
HBASE_CANARY_FAIL_ON_ERROR - Static variable in class org.apache.hadoop.hbase.tool.CanaryTool
 
HBASE_CANARY_READ_RAW_SCAN_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_REGION_READ_TABLE_TIMEOUT - Static variable in class org.apache.hadoop.hbase.tool.CanaryTool
 
HBASE_CANARY_REGION_WRITE_SNIFFING - Static variable in class org.apache.hadoop.hbase.tool.CanaryTool
 
HBASE_CANARY_REGION_WRITE_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.tool.CanaryTool
 
HBASE_CANARY_REGION_WRITE_TABLE_TIMEOUT - Static variable in class org.apache.hadoop.hbase.tool.CanaryTool
 
HBASE_CANARY_REGIONSERVER_ALL_REGIONS - Static variable in class org.apache.hadoop.hbase.tool.CanaryTool
 
HBASE_CANARY_TIMEOUT - Static variable in class org.apache.hadoop.hbase.tool.CanaryTool
 
HBASE_CANARY_USE_REGEX - Static variable in class org.apache.hadoop.hbase.tool.CanaryTool
 
HBASE_CANARY_WRITE_DATA_TTL_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Canary config keys
HBASE_CANARY_WRITE_PERSERVER_REGIONS_LOWERLIMIT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_WRITE_PERSERVER_REGIONS_UPPERLIMIT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_WRITE_TABLE_CHECK_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_WRITE_VALUE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CANARY_ZOOKEEPER_PERMITTED_FAILURES - Static variable in class org.apache.hadoop.hbase.tool.CanaryTool
 
HBASE_CELLS_SCANNED_PER_HEARTBEAT_CHECK - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
The number of cells scanned in between timeout checks.
HBASE_CHECKSUM_VERIFICATION - Static variable in class org.apache.hadoop.hbase.HConstants
If this parameter is set to true, then hbase will read data and then verify checksums.
HBASE_CLIENT_CONNECTION_IMPL - Static variable in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Key for configuration in Configuration whose value is the class we implement making a new HConnection instance.
HBASE_CLIENT_ENABLE_FAST_FAIL_MODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_CLEANUP_DURATION_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_CLEANUP_MS_DURATION_MS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_INTERCEPTOR_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_MODE_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
Config for enabling/disabling the fast fail mode.
HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_INSTANCE_ID - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for unique identifier for this Configuration instance.
HBASE_CLIENT_IPC_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client IPC pool size
HBASE_CLIENT_IPC_POOL_TYPE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client IPC pool type
HBASE_CLIENT_MAX_PERREGION_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent connections the client will maintain to a single Region.
HBASE_CLIENT_MAX_PERSERVER_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent connections the client will maintain to a single RegionServer.
HBASE_CLIENT_MAX_TOTAL_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent connections the client will maintain.
HBASE_CLIENT_META_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client operation timeout.
HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client meta replica scan call timeout.
HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Default HBase client meta replica scan call timeout, 1 second
HBASE_CLIENT_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client operation timeout.
HBASE_CLIENT_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for client pause value, used mostly as value to wait before running a retry of a failed get, region lookup, etc.
HBASE_CLIENT_PAUSE_FOR_CQTBE - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent pending RPC requests for one server in process level.
HBASE_CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for maximum retries, used as maximum for all retryable operations such as fetching of the root region from root region server, getting a cell's value, starting a row update, etc.
HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name to set the default scanner caching for all clients.
HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for maximum number of bytes returned when calling a scanner's next method.
HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
The client scanner timeout period in milliseconds.
HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CONFIG_READ_ZOOKEEPER_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_COORDINATED_STATE_MANAGER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
Config for pluggable consensus provider
HBASE_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase instance root directory
HBASE_DIR_PERMS - Static variable in class org.apache.hadoop.hbase.master.MasterFileSystem
Parameter name for HBase instance root directory permission
HBASE_FLUSH_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
 
HBASE_FLUSH_THROUGHPUT_CONTROLLER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.FlushThroughputControllerFactory
 
HBASE_GROUP_LOADBALANCER_CLASS - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
Config for pluggable load balancers
HBASE_HFILE_COMPACTION_DISCHARGER_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HFILE_COMPACTION_DISCHARGER_THREAD_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_DISCHARGER_THREAD_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_MAX_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_MAX_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_MAX_SIZE_OFFPEAK_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_HIGHER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
 
HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_LOWER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
 
HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_OFFPEAK - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
 
HBASE_HSTORE_COMPACTION_MIN_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_MIN_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_RATIO_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_RATIO_OFFPEAK_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_THROUGHPUT_TUNE_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
 
HBASE_HSTORE_FLUSH_MAX_THROUGHPUT_LOWER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
 
HBASE_HSTORE_FLUSH_MAX_THROUGHPUT_UPPER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
 
HBASE_HSTORE_FLUSH_THROUGHPUT_CONTROL_CHECK_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
 
HBASE_HSTORE_FLUSH_THROUGHPUT_TUNE_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
 
HBASE_HSTORE_MIN_LOCALITY_TO_SKIP_MAJOR_COMPACT - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_OFFPEAK_END_HOUR - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_OFFPEAK_START_HOUR - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HTTP_STATIC_USER - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
 
HBASE_JETTY_LOGS_SERVE_ALIASES - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
Enable/Disable aliases serving from jetty
HBASE_MASTER_BALANCER_MAX_RIT_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
Config for the max percent of regions in transition
HBASE_MASTER_LOADBALANCE_BYTABLE - Static variable in class org.apache.hadoop.hbase.HConstants
Config for balancing the cluster by table
HBASE_MASTER_LOADBALANCER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
Config for pluggable load balancers
HBASE_MASTER_LOGCLEANER_PLUGINS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_MASTER_NORMALIZER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
Config for pluggable region normalizer
HBASE_MAX_CELL_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
HBASE_META_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for number of versions, kept by meta table.
HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for number of rows that will be fetched when calling next on a scanner if it is not served from memory.
HBASE_META_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for number of versions, kept by meta table.
HBASE_METRICS_SYSTEM_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.BaseSource
 
HBASE_NON_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
Directories that are not HBase table directories
HBASE_NON_USER_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
Directories that are not HBase user table directories
HBASE_REGION_SPLIT_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_REGIONSERVER_LEASE_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
This config option is deprecated. Will be removed at later releases after 0.96.
HBASE_RPC_READ_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
timeout for each read RPC
HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
timeout for short operation RPC
HBASE_RPC_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
HBASE_RPC_WRITE_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
timeout for each write RPC
HBASE_RS_HEAP_MEMORY_TUNER_CLASS - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
HBASE_RS_HEAP_MEMORY_TUNER_DEFAULT_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
HBASE_RS_HEAP_MEMORY_TUNER_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
HBASE_RS_NONCES_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
Whether nonces are enabled; default is true.
HBASE_RSGROUP_LOADBALANCER_CLASS - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupableBalancer
Config for pluggable load balancers
HBASE_SECURITY_AUTHORIZATION_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.User
 
HBASE_SECURITY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.User
 
HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for server pause value, used mostly as value to wait before running a retry of a failed operation.
HBASE_SERVER_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for maximum number of bytes returned when calling a scanner's next method.
HBASE_SNAPSHOT_ENABLED - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Enable or disable snapshot support
HBASE_SNAPSHOT_SENTINELS_CLEANUP_TIMEOUT_MILLIS - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Wait time before removing a finished sentinel from the in-progress map NOTE: This is used as a safety auto cleanup.
HBASE_SPLITLOG_MANAGER_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for SplitLog manager timeout
HBASE_SSL_ENABLED_DEFAULT - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
 
HBASE_SSL_ENABLED_KEY - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
Enable/Disable ssl for http server
HBASE_TEMP_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
Temporary directory used for table creation and deletion
HBASE_THROUGHPUT_CONTROLLER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.CompactionThroughputControllerFactory
 
HBASE_WAL_DIR - Static variable in class org.apache.hadoop.hbase.fs.HFileSystem
Parameter name for HBase WAL directory
HBASE_WAL_DIR_PERMS - Static variable in class org.apache.hadoop.hbase.master.MasterFileSystem
Parameter name for HBase WAL directory permission
HBaseAdmin - Class in org.apache.hadoop.hbase.client
HBaseAdmin is no longer a client API.
HBaseAdmin(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
Constructing HBaseAdmin objects manually has been deprecated. Use Connection.getAdmin() to obtain an instance of Admin instead.
HBaseAdmin(Connection) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
Constructing HBaseAdmin objects manually has been deprecated. Use Connection.getAdmin() to obtain an instance of Admin instead.
HBaseAdmin.ProcedureFuture<V> - Class in org.apache.hadoop.hbase.client
Future that waits on a procedure result.
HBaseAdmin.ProcedureFuture(HBaseAdmin, Long) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
HBaseAdmin.ProcedureFuture(HBaseAdmin, Long, boolean) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
HBaseAdmin.ProcedureFuture.WaitForStateCallable - Interface in org.apache.hadoop.hbase.client
 
HBASECLIENT_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for what hbase client implementation to use.
HBaseConfiguration - Class in org.apache.hadoop.hbase
Adds HBase configuration files to a Configuration
HBaseConfiguration() - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
Deprecated.
since 0.90.0. Please use HBaseConfiguration.create() instead.
HBaseConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
Deprecated.
since 0.90.0. Please use HBaseConfiguration.create(Configuration) instead.
HBaseConfTool - Class in org.apache.hadoop.hbase.util
Tool that prints out a configuration.
HBaseConfTool() - Constructor for class org.apache.hadoop.hbase.util.HBaseConfTool
 
HBaseException - Exception in org.apache.hadoop.hbase.exceptions
Base checked exception in HBase.
HBaseException() - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
 
HBaseException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
 
HBaseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
 
HBaseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
 
HBaseFsck - Class in org.apache.hadoop.hbase.util
HBaseFsck (hbck) is a tool for checking and repairing region consistency and table integrity problems in a corrupted HBase.
HBaseFsck(Configuration) - Constructor for class org.apache.hadoop.hbase.util.HBaseFsck
Constructor
HBaseFsck(Configuration, ExecutorService) - Constructor for class org.apache.hadoop.hbase.util.HBaseFsck
Constructor
HBaseFsck.ErrorReporter - Interface in org.apache.hadoop.hbase.util
 
HBaseFsck.ErrorReporter.ERROR_CODE - Enum in org.apache.hadoop.hbase.util
 
HBaseFsck.HbckInfo - Class in org.apache.hadoop.hbase.util
Maintain information about a particular region.
HBaseFsck.RegionRepairException - Exception in org.apache.hadoop.hbase.util
Exception thrown when a integrity repair operation fails in an unresolvable way.
HBaseFsck.RegionRepairException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.util.HBaseFsck.RegionRepairException
 
HBaseFsck.TableInfo - Class in org.apache.hadoop.hbase.util
Maintain information about a particular table.
HBaseFsckRepair - Class in org.apache.hadoop.hbase.util
This class contains helper methods that repair parts of hbase's filesystem contents.
HBaseFsckRepair() - Constructor for class org.apache.hadoop.hbase.util.HBaseFsckRepair
 
HbaseHandlerMetricsProxy - Class in org.apache.hadoop.hbase.thrift
Converts a Hbase.Iface using InvocationHandler so that it reports process time of each call to ThriftMetrics.
HBaseHTraceConfiguration - Class in org.apache.hadoop.hbase.trace
 
HBaseHTraceConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.trace.HBaseHTraceConfiguration
 
HBaseInterClusterReplicationEndpoint - Class in org.apache.hadoop.hbase.replication.regionserver
A ReplicationEndpoint implementation for replicating to another HBase cluster.
HBaseInterClusterReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
 
HBaseInterClusterReplicationEndpoint.Replicator - Class in org.apache.hadoop.hbase.replication.regionserver
 
HBaseInterClusterReplicationEndpoint.Replicator(List<WAL.Entry>, int) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint.Replicator
 
HBaseInterfaceAudience - Class in org.apache.hadoop.hbase
This class defines constants for different classes of hbase limited private apis
HBaseInterfaceAudience() - Constructor for class org.apache.hadoop.hbase.HBaseInterfaceAudience
 
HBaseIOException - Exception in org.apache.hadoop.hbase
All hbase specific IOExceptions should be subclasses of HBaseIOException
HBaseIOException() - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseIOException(String) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseMetrics2HadoopMetricsAdapter - Class in org.apache.hadoop.hbase.metrics.impl
This is the adapter from "HBase Metrics Framework", implemented in hbase-metrics-api and hbase-metrics modules to the Hadoop Metrics2 framework.
HBaseMetrics2HadoopMetricsAdapter() - Constructor for class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
 
HBasePolicyProvider - Class in org.apache.hadoop.hbase.security
Implementation of secure Hadoop policy provider for mapping protocol interfaces to hbase-policy.xml entries.
HBasePolicyProvider() - Constructor for class org.apache.hadoop.hbase.security.HBasePolicyProvider
 
HBaseReplicationEndpoint - Class in org.apache.hadoop.hbase.replication
A BaseReplicationEndpoint for replication endpoints whose target cluster is an HBase cluster.
HBaseReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
HBaseReplicationEndpoint.PeerRegionServerListener - Class in org.apache.hadoop.hbase.replication
Tracks changes to the list of region servers in a peer's cluster.
HBaseReplicationEndpoint.PeerRegionServerListener(HBaseReplicationEndpoint) - Constructor for class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.PeerRegionServerListener
 
HBaseRpcController - Interface in org.apache.hadoop.hbase.ipc
Optionally carries Cells across the proxy/service interface down into ipc.
HBaseRpcController.CancellationCallback - Interface in org.apache.hadoop.hbase.ipc
 
HBaseRpcControllerImpl - Class in org.apache.hadoop.hbase.ipc
Optionally carries Cells across the proxy/service interface down into ipc.
HBaseRpcControllerImpl() - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
HBaseRpcControllerImpl(CellScanner) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
HBaseRpcControllerImpl(List<CellScannable>) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
HBaseRPCErrorHandler - Interface in org.apache.hadoop.hbase.ipc
An interface for calling out of RPC for error conditions.
HBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
A utility class that encapsulates SASL logic for RPC client.
HBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
 
HBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
 
HBaseSaslRpcServer - Class in org.apache.hadoop.hbase.security
A utility class for dealing with SASL on RPC server
HBaseSaslRpcServer() - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
 
HBaseSaslRpcServer.SaslDigestCallbackHandler - Class in org.apache.hadoop.hbase.security
CallbackHandler for SASL DIGEST-MD5 mechanism
HBaseSaslRpcServer.SaslDigestCallbackHandler(SecretManager<TokenIdentifier>, RpcServer.Connection) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslDigestCallbackHandler
 
HBaseSaslRpcServer.SaslGssCallbackHandler - Class in org.apache.hadoop.hbase.security
CallbackHandler for SASL GSSAPI Kerberos mechanism
HBaseSaslRpcServer.SaslGssCallbackHandler() - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslGssCallbackHandler
 
HBaseSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
General exception base class for when a snapshot fails.
HBaseSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Some exception happened for a snapshot and don't even know the snapshot that it was about.
HBaseSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Deprecated.
since 1.3.0, will be removed in 3.0.0
HBaseSnapshotException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Deprecated.
since 1.3.0, will be removed in 3.0.0
HBaseSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Exception when the description of the snapshot cannot be determined, due to some root other root cause.
HBaseZeroCopyByteString - Class in com.google.protobuf
Helper class to extract byte arrays from ByteString without copy.
HBCK_CODE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
HBCK special code name used as server name when manipulating ZK nodes
HBCK_CODE_SERVERNAME - Static variable in class org.apache.hadoop.hbase.master.AssignmentManager
 
HBCK_SIDELINEDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used by HBCK to sideline backup data
HBTop - Class in org.apache.hadoop.hbase.hbtop
A real-time monitoring tool for HBase like Unix top command.
HBTop() - Constructor for class org.apache.hadoop.hbase.hbtop.HBTop
 
HBTop(Configuration) - Constructor for class org.apache.hadoop.hbase.hbtop.HBTop
 
HColumnDescriptor - Class in org.apache.hadoop.hbase
An HColumnDescriptor contains information about a column family such as the number of versions, compression settings, etc.
HColumnDescriptor() - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-5453). This will be made private in HBase 2.0.0. Used by Writables and Writables are going away.
HColumnDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Construct a column descriptor specifying only the family name The other attributes are defaulted.
HColumnDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Construct a column descriptor specifying only the family name The other attributes are defaulted.
HColumnDescriptor(HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Constructor.
HColumnDescriptor(byte[], int, String, boolean, boolean, int, String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HColumnDescriptor(byte[], int, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HColumnDescriptor(byte[], int, int, KeepDeletedCells, String, boolean, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HConnectable<T> - Class in org.apache.hadoop.hbase.client
This class makes it convenient for one to execute a command in the context of a HConnection instance based on the given Configuration.
HConnectable(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HConnectable
 
HConnection - Interface in org.apache.hadoop.hbase.client
Deprecated.
HConnectionManager - Class in org.apache.hadoop.hbase.client
Deprecated.
Please use ConnectionFactory instead
HConstants - Class in org.apache.hadoop.hbase
HConstants holds a bunch of HBase-related constants
HConstants.Modify - Enum in org.apache.hadoop.hbase
modifyTable op for replacing the table descriptor
HConstants.OperationStatusCode - Enum in org.apache.hadoop.hbase
Status codes used for return values of bulk operations.
HDFSBlocksDistribution - Class in org.apache.hadoop.hbase
Data structure to describe the distribution of HDFS blocks among hosts.
HDFSBlocksDistribution() - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution
Constructor
HDFSBlocksDistribution.HostAndWeight - Class in org.apache.hadoop.hbase
Stores the hostname and weight for that hostname.
HDFSBlocksDistribution.HostAndWeight(String, long) - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
Constructor
HDFSBlocksDistribution.HostAndWeight.WeightComparator - Class in org.apache.hadoop.hbase
comparator used to sort hosts based on weight
HDFSBlocksDistribution.HostAndWeight.WeightComparator() - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator
 
head(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a HEAD request
head(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a HEAD request
head(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
Header - Class in org.apache.hadoop.hbase.hbtop.screen.top
Represents headers for the metrics in the top screen.
Header(Field, int) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.Header
 
header - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
HEADER_DEFAULT - Static variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
 
HEADER_USER_AGENT - Static variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
 
headerSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Returns the size of this block header.
headerSize(boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Maps a minor version to the size of the header.
headMap(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
headMap(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
headMap(K, boolean) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
headSet(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
headSet(Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
headSet(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
HEALTH_CHORE_WAKE_FREQ - Static variable in class org.apache.hadoop.hbase.HConstants
 
HEALTH_FAILURE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of health check failures a server can encounter consecutively.
HEALTH_SCRIPT_LOC - Static variable in class org.apache.hadoop.hbase.HConstants
Health script related settings.
HEALTH_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HealthCheckChore - Class in org.apache.hadoop.hbase
The Class HealthCheckChore for running health checker regularly.
HealthCheckChore(int, Stoppable, Configuration) - Constructor for class org.apache.hadoop.hbase.HealthCheckChore
 
heap - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
heap - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
HEAP_OCCUPANCY_ERROR_VALUE - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
HEAP_OCCUPANCY_HIGH_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HEAP_OCCUPANCY_LOW_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HeapMemoryManager - Class in org.apache.hadoop.hbase.regionserver
Manages tuning of Heap memory using HeapMemoryTuner.
HeapMemoryManager.TunerContext - Class in org.apache.hadoop.hbase.regionserver
POJO to pass all the relevant information required to do the heap memory tuning.
HeapMemoryManager.TunerContext() - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
HeapMemoryManager.TunerResult - Class in org.apache.hadoop.hbase.regionserver
POJO which holds the result of memory tuning done by HeapMemoryTuner implementation.
HeapMemoryManager.TunerResult(boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
 
HeapMemorySizeUtil - Class in org.apache.hadoop.hbase.io.util
 
HeapMemorySizeUtil() - Constructor for class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
 
HeapMemoryTuner - Interface in org.apache.hadoop.hbase.regionserver
Makes the decision regarding proper sizing of the heap memory.
HeapMemStoreLAB - Class in org.apache.hadoop.hbase.regionserver
A memstore-local allocation buffer.
HeapMemStoreLAB() - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
 
HeapMemStoreLAB(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
 
heapSize() - Method in class org.apache.hadoop.hbase.client.Mutation
 
HeapSize - Interface in org.apache.hadoop.hbase.io
Implementations can be asked for an estimate of their size in bytes.
heapSize() - Method in interface org.apache.hadoop.hbase.io.HeapSize
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
Strings have two bytes per character due to default Java Unicode encoding (hence length times 2).
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
HeapSize implementation NOTE : The heapsize should be altered as and when new state variable are added
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
Total size of all elements in this queue.
heapSize() - Method in class org.apache.hadoop.hbase.KeyValue
HeapSize implementation We do not count the bytes in the rowCache because it should be empty for a KeyValue in the MemStore.
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Get the entire heap usage for this MemStore not including keys in the snapshot.
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
heapSize - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The precomputed heap size of this entry
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns the pre-computed and "deep" size of the Entry
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
The total memory usage of this map
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
heapSize() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
heapSize() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer
 
HEAPSIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
heapSizeWithoutTags() - Method in class org.apache.hadoop.hbase.KeyValue
Deprecated.
heartbeat(long, int, ServerName) - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
heartbeatMessage - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
Saves whether or not the most recent response from the server was a heartbeat message.
heartbeatNoDetails(long) - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
hedgedReadOps - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
hedgedReadWin - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
HelloHBase - Class in org.apache.hbase.archetypes.exemplars.client
Successful running of this application requires access to an active instance of HBase.
HelloHBase - Class in org.apache.hbase.archetypes.exemplars.shaded_client
Successful running of this application requires access to an active instance of HBase.
HelpScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.help
The presentation logic for the help screen.
HelpScreenPresenter(HelpScreenView, long, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenPresenter
 
HelpScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.help
The help screen.
HelpScreenView(Screen, Terminal, long, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
 
HFile - Class in org.apache.hadoop.hbase.io.hfile
File format for hbase.
HFile() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile
 
HFile.CachingBlockReader - Interface in org.apache.hadoop.hbase.io.hfile
An abstraction used by the block index.
HFile.FileInfo - Class in org.apache.hadoop.hbase.io.hfile
Metadata for this file.
HFile.FileInfo() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
HFile.Reader - Interface in org.apache.hadoop.hbase.io.hfile
An interface used by clients to open and iterate an HFile.
HFile.Writer - Interface in org.apache.hadoop.hbase.io.hfile
API required to write an HFile
HFile.WriterFactory - Class in org.apache.hadoop.hbase.io.hfile
This variety of ways to construct writers is used throughout the code, and we want to be able to swap writer implementations.
HFILE_ARCHIVE_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
Directory under /hbase where archived hfiles are stored
HFILE_ARCHIVE_ZNODE_PARENT - Static variable in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
 
HFILE_BLOCK_CACHE_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HFILE_BLOCK_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the size of the block cache
HFILE_CACHE_REFRESH_PERIOD_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
Conf key for the frequency to attempt to refresh the cache of hfiles currently used in snapshots (ms)
HFILE_DELETE_THREAD_CHECK_INTERVAL_MSEC - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
HFILE_DELETE_THREAD_TIMEOUT_MSEC - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
HFILE_DELETE_THROTTLE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
HFILE_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
A non-capture group, for hfiles, so that this can be embedded.
HFileArchiver - Class in org.apache.hadoop.hbase.backup
Utility class to handle the removal of HFiles (or the respective StoreFiles) for a HRegion from the FileSystem.
HFileArchiveTableMonitor - Class in org.apache.hadoop.hbase.backup.example
Monitor the actual tables for which HFiles are archived for long-term retention (always kept unless ZK state changes).
HFileArchiveTableMonitor() - Constructor for class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
 
HFileArchiveUtil - Class in org.apache.hadoop.hbase.util
Helper class for all utilities related to archival/retrieval of HFiles
HFileBlock - Class in org.apache.hadoop.hbase.io.hfile
Reads HFile version 2 blocks to HFiles and via Cacheable Interface to caches.
HFileBlock(BlockType, int, int, long, ByteBuffer, boolean, long, int, int, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlock
Creates a new HFile block from the given fields.
HFileBlock.Writer - Class in org.apache.hadoop.hbase.io.hfile
Unified version 2 HFile block writer.
HFileBlock.Writer(HFileDataBlockEncoder, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
 
HFILEBLOCK_DUMMY_HEADER - Static variable in class org.apache.hadoop.hbase.HConstants
Just an array of bytes of the right size.
HFILEBLOCK_HEADER_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
The size of a version 2 HFile block header, minor version 1.
HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM - Static variable in class org.apache.hadoop.hbase.HConstants
The size data structures with minor version is 0
HFileBlockDecodingContext - Interface in org.apache.hadoop.hbase.io.encoding
A decoding context that is created by a reader's encoder, and is shared across the reader's all read operations.
HFileBlockDefaultDecodingContext - Class in org.apache.hadoop.hbase.io.encoding
A default implementation of HFileBlockDecodingContext.
HFileBlockDefaultDecodingContext(HFileContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
 
HFileBlockDefaultEncodingContext - Class in org.apache.hadoop.hbase.io.encoding
A default implementation of HFileBlockEncodingContext.
HFileBlockDefaultEncodingContext(DataBlockEncoding, byte[], HFileContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
HFileBlockEncodingContext - Interface in org.apache.hadoop.hbase.io.encoding
An encoding context that is created by a writer's encoder, and is shared across the writer's whole lifetime.
HFileBlockIndex - Class in org.apache.hadoop.hbase.io.hfile
Provides functionality to write (HFileBlockIndex.BlockIndexWriter) and read BlockIndexReader single-level and multi-level block indexes.
HFileBlockIndex() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
 
HFileBlockIndex.BlockIndexReader - Class in org.apache.hadoop.hbase.io.hfile
The reader will always hold the root level index in the memory.
HFileBlockIndex.BlockIndexReader(KeyValue.KVComparator, int, HFile.CachingBlockReader) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
HFileBlockIndex.BlockIndexReader(KeyValue.KVComparator, int) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
HFileBlockIndex.BlockIndexWriter - Class in org.apache.hadoop.hbase.io.hfile
Writes the block index into the output stream.
HFileBlockIndex.BlockIndexWriter() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Creates a single-level block index writer
HFileBlockIndex.BlockIndexWriter(HFileBlock.Writer, CacheConfig, String) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Creates a multi-level block index writer.
HFileCleaner - Class in org.apache.hadoop.hbase.master.cleaner
This Chore, every time it runs, will clear the HFiles in the hfile archive folder that are deletable for each HFile cleaner in the chain.
HFileCleaner(int, Stoppable, Configuration, FileSystem, Path, DirScanPool) - Constructor for class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
HFileCleaner(int, Stoppable, Configuration, FileSystem, Path, DirScanPool, Map<String, Object>) - Constructor for class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
hFileContext - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
 
HFileContext - Class in org.apache.hadoop.hbase.io.hfile
This carries the information on some of the meta data about the HFile.
HFileContext() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContext
 
HFileContext(HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContext
Copy constructor
HFileContext(boolean, boolean, boolean, Compression.Algorithm, boolean, ChecksumType, int, int, DataBlockEncoding, Encryption.Context, long, String) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContext
 
HFileContextBuilder - Class in org.apache.hadoop.hbase.io.hfile
A builder that helps in building up the HFileContext
HFileContextBuilder() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
HFileContextBuilder(HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
Use this constructor if you want to change a few settings only in another context.
HFileCorruptionChecker - Class in org.apache.hadoop.hbase.util.hbck
This class marches through all of the region's hfiles and verifies that they are all valid files.
HFileCorruptionChecker(Configuration, ExecutorService, boolean) - Constructor for class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
 
HFileDataBlockEncoder - Interface in org.apache.hadoop.hbase.io.hfile
Controls what kind of data block encoding is used.
HFileDataBlockEncoderImpl - Class in org.apache.hadoop.hbase.io.hfile
Do different kinds of data block encoding according to column family options.
HFileDataBlockEncoderImpl(DataBlockEncoding) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
Do data block encoding with specified options.
HFileLink - Class in org.apache.hadoop.hbase.io
HFileLink describes a link to an hfile.
HFileLink(Path, Path, Path) - Constructor for class org.apache.hadoop.hbase.io.HFileLink
Dead simple hfile link constructor
HFileLinkCleaner - Class in org.apache.hadoop.hbase.master.cleaner
HFileLink cleaner that determines if a hfile should be deleted.
HFileLinkCleaner() - Constructor for class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
 
HFileOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
Deprecated.
use HFileOutputFormat2 instead.
HFileOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
Deprecated.
 
HFileOutputFormat2 - Class in org.apache.hadoop.hbase.mapreduce
Writes HFiles.
HFileOutputFormat2() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
HFilePrettyPrinter - Class in org.apache.hadoop.hbase.io.hfile
Implements pretty-printing functionality for HFiles.
HFilePrettyPrinter() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
 
HFilePrettyPrinter(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
 
HFileReaderV2 - Class in org.apache.hadoop.hbase.io.hfile
HFile reader for version 2.
HFileReaderV2(Path, FixedFileTrailer, FSDataInputStreamWrapper, long, CacheConfig, HFileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
Opens a HFile.
HFileReaderV2.AbstractScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
 
HFileReaderV2.AbstractScannerV2(HFileReaderV2, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
HFileReaderV2.EncodedScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
ScannerV2 that operates on encoded data blocks.
HFileReaderV2.EncodedScannerV2(HFileReaderV2, boolean, boolean, boolean, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
HFileReaderV2.ScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
Implementation of HFileScanner interface.
HFileReaderV2.ScannerV2(HFileReaderV2, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
HFileReaderV3 - Class in org.apache.hadoop.hbase.io.hfile
HFile reader for version 3.
HFileReaderV3(Path, FixedFileTrailer, FSDataInputStreamWrapper, long, CacheConfig, HFileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
Opens a HFile.
HFileReaderV3.EncodedScannerV3 - Class in org.apache.hadoop.hbase.io.hfile
ScannerV3 that operates on encoded data blocks.
HFileReaderV3.EncodedScannerV3(HFileReaderV3, boolean, boolean, boolean, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.EncodedScannerV3
 
HFileReaderV3.ScannerV3 - Class in org.apache.hadoop.hbase.io.hfile
Implementation of HFileScanner interface.
HFileReaderV3.ScannerV3(HFileReaderV3, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
 
hfileRefsZNode - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the znode that contains queues of hfile references to be replicated
HFileReplicator - Class in org.apache.hadoop.hbase.replication.regionserver
It is used for replicating HFile entries.
HFileReplicator(Configuration, String, String, Map<String, List<Pair<byte[], List<String>>>>, Configuration, Connection, List<String>) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
 
HFileScanner - Interface in org.apache.hadoop.hbase.io.hfile
A scanner allows you to position yourself within a HFile and scan through it.
HFileSystem - Class in org.apache.hadoop.hbase.fs
An encapsulation for the FileSystem object that hbase uses to access data.
HFileSystem(Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.fs.HFileSystem
Create a FileSystem object for HBase regionservers.
HFileSystem(FileSystem) - Constructor for class org.apache.hadoop.hbase.fs.HFileSystem
Wrap a FileSystem object within a HFileSystem.
HFileV1Detector - Class in org.apache.hadoop.hbase.util
Tool to detect presence of any HFileV1 in the given directory.
HFileV1Detector() - Constructor for class org.apache.hadoop.hbase.util.HFileV1Detector
 
HFileWriterV2 - Class in org.apache.hadoop.hbase.io.hfile
Writes HFile format version 2.
HFileWriterV2(Configuration, CacheConfig, FileSystem, Path, FSDataOutputStream, KeyValue.KVComparator, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Constructor that takes a path, creates and closes the output stream.
HFileWriterV3 - Class in org.apache.hadoop.hbase.io.hfile
HFile writer for version 3.
HFileWriterV3(Configuration, CacheConfig, FileSystem, Path, FSDataOutputStream, KeyValue.KVComparator, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
Constructor that takes a path, creates and closes the output stream.
hfs - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
The filesystem used for accesing data
hideCursor() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
hideCursor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
 
hideCursor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
hideCursor() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
 
HIGH_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
higher(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
higherEntry(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
higherKey(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
hint - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
HINT_LOOKAHEAD - Static variable in class org.apache.hadoop.hbase.client.Scan
Deprecated.
without replacement This is now a no-op, SEEKs and SKIPs are optimizated automatically. Will be removed in 2.0+
Histogram - Interface in org.apache.hadoop.hbase.metrics
A metric which measures the distribution of values.
histogram - Variable in class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
 
histogram(String) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
histogram(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
Get or construct a Histogram used to measure a distribution of values.
histogram - Variable in class org.apache.hadoop.metrics2.lib.MutableHistogram
 
HistogramImpl - Class in org.apache.hadoop.hbase.metrics.impl
Custom histogram implementation based on FastLongHistogram.
HistogramImpl() - Constructor for class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
 
HistogramImpl(long) - Constructor for class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
 
HistogramImpl(int, long, long) - Constructor for class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
 
HistogramImpl(CounterImpl, FastLongHistogram) - Constructor for class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
 
hit(boolean, boolean, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
HLogInputFormat - Class in org.apache.hadoop.hbase.mapreduce
Deprecated.
HLogInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
Deprecated.
 
HLogKey - Class in org.apache.hadoop.hbase.regionserver.wal
Deprecated.
use WALKey
HLogKey() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
 
HLogKey(byte[], TableName, long, long, UUID) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
 
HLogKey(byte[], TableName) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
 
HLogKey(byte[], TableName, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
 
HLogKey(byte[], TableName, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
 
HLogKey(byte[], TableName, long, long, List<UUID>, long, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
Create the log key for writing to somewhere.
HLogKey(byte[], TableName, long, List<UUID>, long, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
Create the log key for writing to somewhere.
HLogKey(byte[], TableName, long, long, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
Create the log key for writing to somewhere.
HLogPrettyPrinter - Class in org.apache.hadoop.hbase.regionserver.wal
Deprecated.
use the "hbase wal" command
HLogPrettyPrinter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
Deprecated.
Basic constructor that simply initializes values to reasonable defaults.
HLogPrettyPrinter(boolean, boolean, long, String, String, boolean, PrintStream) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
Deprecated.
Fully specified constructor.
HMaster - Class in org.apache.hadoop.hbase.master
HMaster is the "master server" for HBase.
HMaster(Configuration, CoordinatedStateManager) - Constructor for class org.apache.hadoop.hbase.master.HMaster
Initializes the HMaster.
HMaster.RedirectServlet - Class in org.apache.hadoop.hbase.master
 
HMaster.RedirectServlet(InfoServer, String) - Constructor for class org.apache.hadoop.hbase.master.HMaster.RedirectServlet
 
HMasterCommandLine - Class in org.apache.hadoop.hbase.master
 
HMasterCommandLine(Class<? extends HMaster>) - Constructor for class org.apache.hadoop.hbase.master.HMasterCommandLine
 
HMasterCommandLine.LocalHMaster - Class in org.apache.hadoop.hbase.master
 
HMasterCommandLine.LocalHMaster(Configuration, CoordinatedStateManager) - Constructor for class org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
 
hMemManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
home() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
home() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
host - Static variable in class org.apache.hadoop.hbase.thrift.DemoClient
 
host - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
 
hostAddress - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
hostName(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
Set the hostname of the http server.
hostName - Variable in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
HOSTNAME_PORT_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Addressing
 
HOUR_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HQuorumPeer - Class in org.apache.hadoop.hbase.zookeeper
HBase's version of ZooKeeper's QuorumPeer.
HQuorumPeer() - Constructor for class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
 
HRegion - Class in org.apache.hadoop.hbase.regionserver
 
HRegion(Path, WAL, FileSystem, Configuration, HRegionInfo, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
Deprecated.
Use other constructors.
HRegion(HRegionFileSystem, WAL, Configuration, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
HRegion constructor.
HRegion.FlushResultImpl - Class in org.apache.hadoop.hbase.regionserver
Objects from this class are created when flushing to describe all the different states that that method ends up in.
HRegion.RowLockImpl - Class in org.apache.hadoop.hbase.regionserver
Class used to represent a lock on a row.
HRegion.RowLockImpl(HRegion.RowLockContext, Lock) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
 
HREGION_COLUMNFAMILY_FLUSH_SIZE_LOWER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
 
HREGION_COMPACTIONDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used to construct the name of the compaction directory during compaction
HREGION_EDITS_REPLAY_SKIP_ERRORS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HREGION_LOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used to construct the name of the log directory for a region server
HREGION_MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key for the max file size after which we split the region
HREGION_MEMSTORE_BLOCK_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
Block updates if memstore has hbase.hregion.memstore.block.multiplier times hbase.hregion.memstore.flush.size bytes.
HREGION_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key for the memstore size at which we flush the memstore
HREGION_MVCC_PRE_ASSIGN - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
Config key for using mvcc pre-assign feature for put
HREGION_OLDLOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Like the previous, but for old logs that are about to be deleted
HREGION_VERSION - Static variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
 
HRegionFileSystem - Class in org.apache.hadoop.hbase.regionserver
View to an on-disk Region.
HRegionInfo - Class in org.apache.hadoop.hbase
Information about a region.
HRegionInfo(long, TableName, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
 
HRegionInfo() - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 0.96 (HBASE-5453). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
HRegionInfo(TableName) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
 
HRegionInfo(TableName, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean, long) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean, long, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Costruct a copy of another HRegionInfo
HRegionInfo(HRegionInfo, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
 
HRegionLocation - Class in org.apache.hadoop.hbase
Data structure to hold HRegionInfo and the address for the hosting HRegionServer.
HRegionLocation(HRegionInfo, ServerName) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
 
HRegionLocation(HRegionInfo, ServerName, long) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
 
HRegionLocator - Class in org.apache.hadoop.hbase.client
An implementation of RegionLocator.
HRegionLocator(TableName, ClusterConnection) - Constructor for class org.apache.hadoop.hbase.client.HRegionLocator
 
HRegionPartitioner<K2,V2> - Class in org.apache.hadoop.hbase.mapred
This is used to partition the output keys into groups of keys.
HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapred.HRegionPartitioner
 
HRegionPartitioner<KEY,VALUE> - Class in org.apache.hadoop.hbase.mapreduce
This is used to partition the output keys into groups of keys.
HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
 
HRegionServer - Class in org.apache.hadoop.hbase.regionserver
HRegionServer makes a set of HRegions available to clients.
HRegionServer(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer
Starts a HRegionServer at the default location.
HRegionServer(Configuration, CoordinatedStateManager) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer
Starts a HRegionServer at the default location
HRegionServer.MovedRegionsCleaner - Class in org.apache.hadoop.hbase.regionserver
Creates a Chore thread to clean the moved region cache.
HRegionServerCommandLine - Class in org.apache.hadoop.hbase.regionserver
Class responsible for parsing the command line and starting the RegionServer.
HRegionServerCommandLine(Class<? extends HRegionServer>) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
 
HStore - Class in org.apache.hadoop.hbase.regionserver
A Store holds a column family in a Region.
HStore(HRegion, HColumnDescriptor, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HStore
Constructor
HSTORE_OPEN_AND_CLOSE_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
The max number of threads used for opening and closing stores or store files in parallel
HTable - Class in org.apache.hadoop.hbase.client
An implementation of Table.
HTable(Configuration, String) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(Configuration, byte[]) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(Configuration, TableName) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(TableName, Connection) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Do not use.
HTable(Configuration, byte[], ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(Configuration, TableName, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(byte[], Connection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Do not use, internal ctor.
HTable(TableName, Connection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Do not use, internal ctor.
HTable(TableName, ClusterConnection, ConnectionConfiguration, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Creates an object to access a HBase table.
HTable(ClusterConnection, BufferedMutatorParams) - Constructor for class org.apache.hadoop.hbase.client.HTable
For internal testing.
HTableDescriptor - Class in org.apache.hadoop.hbase
HTableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table, -ROOT- or hbase:meta , if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc...
HTableDescriptor(TableName, HColumnDescriptor[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Private constructor used internally creating table descriptors for catalog tables, hbase:meta and -ROOT-.
HTableDescriptor(TableName, HColumnDescriptor[], Map<ImmutableBytesWritable, ImmutableBytesWritable>) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Private constructor used internally creating table descriptors for catalog tables, hbase:meta and -ROOT-.
HTableDescriptor() - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
As of release 0.96 (HBASE-5453). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
HTableDescriptor(TableName) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor specifying a TableName object
HTableDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
HTableDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
HTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor by cloning the descriptor passed as a parameter.
HTableDescriptor(TableName, HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor by cloning the descriptor passed as a parameter but using a different table name.
hTableDescriptor - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
 
HTableFactory - Class in org.apache.hadoop.hbase.client
HTableFactory() - Constructor for class org.apache.hadoop.hbase.client.HTableFactory
Deprecated.
 
HTableInterface - Interface in org.apache.hadoop.hbase.client
Deprecated.
use Table instead
HTableInterfaceFactory - Interface in org.apache.hadoop.hbase.client
Deprecated.
in favor of ConnectionFactory and Connection.
HTableMultiplexer - Class in org.apache.hadoop.hbase.client
HTableMultiplexer provides a thread-safe non blocking PUT API across all the tables.
HTableMultiplexer(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer
 
HTableMultiplexer(Connection, Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer
 
HTableMultiplexer.HTableMultiplexerStatus - Class in org.apache.hadoop.hbase.client
HTableMultiplexerStatus keeps track of the current status of the HTableMultiplexer.
HTableMultiplexer.HTableMultiplexerStatus(Map<HRegionLocation, HTableMultiplexer.FlushWorker>) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
HTablePool - Class in org.apache.hadoop.hbase.client
Deprecated.
as of 0.98.1. See HConnection.getTable(String).
HTablePool() - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Default Constructor.
HTablePool(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Constructor to set maximum versions and use the specified configuration.
HTablePool(Configuration, int, HTableInterfaceFactory) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Constructor to set maximum versions and use the specified configuration and table factory.
HTablePool(Configuration, int, PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Constructor to set maximum versions and use the specified configuration and pool type.
HTablePool(Configuration, int, HTableInterfaceFactory, PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Constructor to set maximum versions and use the specified configuration, table factory and pool type.
HTableUtil - Class in org.apache.hadoop.hbase.client
Deprecated.
since 1.0
HTableUtil() - Constructor for class org.apache.hadoop.hbase.client.HTableUtil
Deprecated.
 
HTableWrapper - Class in org.apache.hadoop.hbase.client
A wrapper for HTable.
htd - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
HThreadedSelectorServerArgs - Class in org.apache.hadoop.hbase.thrift
A TThreadedSelectorServer.Args that reads hadoop configuration
HThreadedSelectorServerArgs(TNonblockingServerTransport, Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
 
HtmlQuoting - Class in org.apache.hadoop.hbase.http
This class is responsible for quoting HTML characters.
HtmlQuoting() - Constructor for class org.apache.hadoop.hbase.http.HtmlQuoting
 
HTTP_AUTHENTICATION_SIGNATURE_SECRET_FILE_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
HTTP_SPNEGO_AUTHENTICATION_KEYTAB_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
HTTP_SPNEGO_AUTHENTICATION_KRB_NAME_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
HTTP_SPNEGO_AUTHENTICATION_PRINCIPAL_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
HTTP_UI_AUTHENTICATION - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
HttpAuthenticationException - Exception in org.apache.hadoop.hbase.thrift
 
HttpAuthenticationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
 
HttpAuthenticationException(String) - Constructor for exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
 
HttpAuthenticationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
 
HttpConfig - Class in org.apache.hadoop.hbase.http
Statics to get access to Http related configuration.
HttpConfig(Configuration) - Constructor for class org.apache.hadoop.hbase.http.HttpConfig
 
HttpConfig.Policy - Enum in org.apache.hadoop.hbase.http
 
HttpDoAsClient - Class in org.apache.hadoop.hbase.thrift
See the instructions under hbase-examples/README.txt
HttpRequestLog - Class in org.apache.hadoop.hbase.http
RequestLog object for use with Http
HttpRequestLog() - Constructor for class org.apache.hadoop.hbase.http.HttpRequestLog
 
HttpRequestLogAppender - Class in org.apache.hadoop.hbase.http
Log4j Appender adapter for HttpRequestLog
HttpRequestLogAppender() - Constructor for class org.apache.hadoop.hbase.http.HttpRequestLogAppender
 
HttpServer - Class in org.apache.hadoop.hbase.http
Create a Jetty embedded server to answer http requests.
HttpServer(String, String, int, boolean) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer(String, String, int, boolean, Configuration, Connector) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer(String, String, int, boolean, Configuration, String[]) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer(String, String, int, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer(String, String, int, boolean, Configuration, AccessControlList) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer(String, String, int, boolean, Configuration, AccessControlList, Connector) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer(String, String, int, boolean, Configuration, AccessControlList, Connector, String[]) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer.Builder - Class in org.apache.hadoop.hbase.http
Class to construct instances of HTTP server with specific options.
HttpServer.Builder() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.Builder
 
HttpServer.QuotingInputFilter - Class in org.apache.hadoop.hbase.http
A Servlet input filter that quotes all HTML active characters in the parameter names and values.
HttpServer.QuotingInputFilter() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
 
HttpServer.QuotingInputFilter.RequestQuoter - Class in org.apache.hadoop.hbase.http
 
HttpServer.QuotingInputFilter.RequestQuoter(HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
 
HttpServer.StackServlet - Class in org.apache.hadoop.hbase.http
A very simple servlet to serve up a text representation of the current stack traces.
HttpServer.StackServlet() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.StackServlet
 
HttpServerUtil - Class in org.apache.hadoop.hbase.util
HttpServer utility.
HttpServerUtil() - Constructor for class org.apache.hadoop.hbase.util.HttpServerUtil
 
humanReadableTimestamp(long) - Static method in class org.apache.hadoop.hbase.KeyValue
 
humanSize(double) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
 
humanTimeDiff(long) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
 

I

I - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'I'
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
ia - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
if the scannerId is invalid
ia - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
if the scannerId is invalid
id - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
id - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
id - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
id - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
id of a scanner returned by scannerOpen
id - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
id of a scanner returned by scannerOpen
id - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
id of a scanner returned by scannerOpen
id - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
ID_ATRIBUTE - Static variable in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
ID_SIZE - Static variable in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
idealMaxKeys(long, double) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
The maximum number of keys we can put into a Bloom filter of a certain size to maintain the given error rate, assuming the number of hash functions is chosen optimally and does not even have to be an integer (hence the "ideal" in the function name).
IdentityTableMap - Class in org.apache.hadoop.hbase.mapred
Pass the given key and record as-is to reduce
IdentityTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableMap
constructor
IdentityTableMapper - Class in org.apache.hadoop.hbase.mapreduce
Pass the given key and record as-is to the reduce phase.
IdentityTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
 
IdentityTableReduce - Class in org.apache.hadoop.hbase.mapred
Write to table each key, record pair
IdentityTableReduce() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableReduce
 
IdentityTableReducer - Class in org.apache.hadoop.hbase.mapreduce
Convenience class that simply writes all values (which must be Put or Delete instances) passed to it out to the configured HBase table.
IdentityTableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
 
IDLE_TIME - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
IdLock - Class in org.apache.hadoop.hbase.util
Allows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.
IdLock() - Constructor for class org.apache.hadoop.hbase.util.IdLock
 
IdLock.Entry - Class in org.apache.hadoop.hbase.util
An entry returned to the client as a lock object
IdReadWriteLock - Class in org.apache.hadoop.hbase.util
Allows multiple concurrent clients to lock on a numeric id with ReentrantReadWriteLock.
IdReadWriteLock() - Constructor for class org.apache.hadoop.hbase.util.IdReadWriteLock
 
idx - Variable in class org.apache.hadoop.hbase.types.StructIterator
 
ignoreZKDeleteForTesting - Variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
IllegalArgument - Exception in org.apache.hadoop.hbase.thrift.generated
 
IllegalArgument() - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
IllegalArgument(String) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
IllegalArgument(IllegalArgument) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
Performs a deep copy on other.
IllegalArgument._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
IllegalArgumentIOException - Exception in org.apache.hadoop.hbase.exceptions
Exception thrown when an illegal argument is passed to a function/procedure.
IllegalArgumentIOException() - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
 
IllegalArgumentIOException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
 
IllegalArgumentIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
 
IllegalArgumentIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
 
immediateAssignment(List<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Generates an immediate assignment plan to be used by a new master for regions in transition that do not have an already known destination.
immediateAssignment(List<HRegionInfo>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Sync assign a region
immediateAssignment(List<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
ImmutableByteArray - Class in org.apache.hadoop.hbase.util
Mainly used as keys for HashMap.
ImmutableBytesWritable - Class in org.apache.hadoop.hbase.io
A byte sequence that is usable as a key or value.
ImmutableBytesWritable() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Create a zero-size sequence.
ImmutableBytesWritable(byte[]) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Create a ImmutableBytesWritable using the byte array as the initial value.
ImmutableBytesWritable(ImmutableBytesWritable) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Set the new ImmutableBytesWritable to the contents of the passed ibw.
ImmutableBytesWritable(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Set the value to a given byte range
ImmutableBytesWritable.Comparator - Class in org.apache.hadoop.hbase.io
A Comparator optimized for ImmutableBytesWritable.
ImmutableBytesWritable.Comparator() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
constructor
impl - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
The coprocessor
implies(Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.Permission
 
implies(String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
Checks that a given table operation is authorized by this permission instance.
implies(TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
Checks that a given table operation is authorized by this permission instance.
implies(TableName, KeyValue, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
Checks if this permission grants access to perform the given action on the given table and key value.
Import - Class in org.apache.hadoop.hbase.mapreduce
Import data written by Export.
Import() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import
 
Import.Importer - Class in org.apache.hadoop.hbase.mapreduce
Write table content out to files in hdfs.
Import.Importer() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.Importer
 
Import.KeyValueImporter - Class in org.apache.hadoop.hbase.mapreduce
A mapper that just writes out KeyValues.
Import.KeyValueImporter() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.KeyValueImporter
 
Import.KeyValueReducer - Class in org.apache.hadoop.hbase.mapreduce
 
Import.KeyValueReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.KeyValueReducer
 
Import.KeyValueSortImporter - Class in org.apache.hadoop.hbase.mapreduce
 
Import.KeyValueSortImporter() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.KeyValueSortImporter
 
Import.KeyValueWritableComparable - Class in org.apache.hadoop.hbase.mapreduce
 
Import.KeyValueWritableComparable() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable
 
Import.KeyValueWritableComparable(KeyValue) - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable
 
Import.KeyValueWritableComparable.KeyValueWritableComparator - Class in org.apache.hadoop.hbase.mapreduce
 
Import.KeyValueWritableComparable.KeyValueWritableComparator() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable.KeyValueWritableComparator
 
Import.KeyValueWritableComparablePartitioner - Class in org.apache.hadoop.hbase.mapreduce
 
Import.KeyValueWritableComparablePartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparablePartitioner
 
IMPORT_FORMAT_VER - Static variable in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
ImportTsv - Class in org.apache.hadoop.hbase.mapreduce
Tool to import data from a TSV file.
ImportTsv() - Constructor for class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
ImportTsv.TsvParser - Class in org.apache.hadoop.hbase.mapreduce
 
ImportTsv.TsvParser(String, String) - Constructor for class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
ImportTsv.TsvParser.BadTsvLineException - Exception in org.apache.hadoop.hbase.mapreduce
 
ImportTsv.TsvParser.BadTsvLineException(String) - Constructor for exception org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.BadTsvLineException
 
in - Variable in class org.apache.hadoop.hbase.codec.BaseDecoder
 
IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HConstants
 
incActiveWorkerCount() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Increment number of active thrift workers.
incActiveWorkerCount() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
incActiveWorkerCount() - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
incarnation - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
incCall(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Add how long a call took
incCall(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
incChildrenLatch() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called by the ProcedureExecutor on procedure-load to restore the latch state
incCounters(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Add some amount to a counter.
incCounters(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
Increment a named counter by some value.
incCounters(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incCounters(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incCounters(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incGauge(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Add some amount to a gauge.
incGauge(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
Add some amount to a gauge.
incGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incInfoThresholdExceeded(int) - Method in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
Increment the INFO level threshold exceeded count
incInfoThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
incInfoThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incInfoThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
INCLUDE_FULL_TREE_IN_TO_STRING - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
print/debug
includeMvccVersion - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
includeMvccVersion - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
includeMvccVersion - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
IncludePublicAnnotationsStandardDoclet - Class in org.apache.hadoop.hbase.classification.tools
A Doclet that only includes class-level elements that are annotated with InterfaceAudience.Public.
IncludePublicAnnotationsStandardDoclet() - Constructor for class org.apache.hadoop.hbase.classification.tools.IncludePublicAnnotationsStandardDoclet
 
includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Test if the given region is to be included in the InputSplit while splitting the regions of a table.
includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Test if the given region is to be included in the InputSplit while splitting the regions of a table.
includesMvcc() - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker
 
includesMvccVersion - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
includesTags() - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker
 
includeStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
 
includesTimeRange(TimeRange) - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if the range has any overlap with TimeRange
includesTimeRange(TimeRange) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
Check if the range has ANY overlap with TimeRange
includeStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
 
includeTable(TableName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
includeTimestamp(Cell) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
Update the current TimestampRange to include the timestamp from cell.
InclusiveCombinedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
 
InclusiveCombinedBlockCache(LruBlockCache, BlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
 
InclusiveStopFilter - Class in org.apache.hadoop.hbase.filter
A Filter that stops after the given row.
InclusiveStopFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
incMethodTime(String, long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Add how long a method took
incMethodTime(String, long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
incMethodTime(String, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
incNumRowKeysInBatchGet(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Add how many keys were in a batch get.
incNumRowKeysInBatchGet(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
incNumRowKeysInBatchGet(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
incNumRowKeysInBatchMutate(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Add how many keys were in a batch mutate.
incNumRowKeysInBatchMutate(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
incNumRowKeysInBatchMutate(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
IncompatibleFilterException - Exception in org.apache.hadoop.hbase.filter
Used to indicate a filter incompatibility
IncompatibleFilterException() - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
constructor
IncompatibleFilterException(String) - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
constructor
incr() - Method in class org.apache.hadoop.metrics2.lib.MutableFastCounter
 
incr(long) - Method in class org.apache.hadoop.metrics2.lib.MutableFastCounter
Increment the value by a delta
incrAppliedBatches(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
 
incrAppliedBatches(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
 
incrAppliedHFiles(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
 
incrAppliedHFiles(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
 
incrAppliedOps(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
 
incrAppliedOps(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
 
incrBatchesShipped(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrBatchesShipped(int) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrBatchesShipped(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrBytesSkippedInUncleanlyClosedWALs(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrBytesSkippedInUncleanlyClosedWALs(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrBytesSkippedInUncleanlyClosedWALs(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrBytesSkippedInUncleanlyClosedWALs(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrCacheDroppingExceptions(Object) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
 
incrCompletedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrCompletedRecoveryQueue() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrCompletedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrCompletedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrCompletedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrCompletedWAL() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrCompletedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrCompletedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrDelayRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of delay runner counts.
incrDelayRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
incReadFailureCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
 
incReadFailureCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
 
incReadSuccessCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
 
incReadSuccessCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
 
IncreasingToUpperBoundRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
Split size is the number of regions that are on this server that all are of the same table, cubed, times 2x the region flush size OR the maximum region split size, whichever is smaller.
IncreasingToUpperBoundRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
 
increment(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
increment(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
increment(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
increment(Increment) - Method in class org.apache.hadoop.hbase.client.HTable
Increments one or more columns within a single row.
increment(Increment) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
Increment - Class in org.apache.hadoop.hbase.client
Used to perform Increment operations on a single row.
Increment(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Increment
Create a Increment operation for the specified row.
Increment(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Increment
Create a Increment operation for the specified row.
Increment(Increment) - Constructor for class org.apache.hadoop.hbase.client.Increment
Copy constructor
increment(Increment) - Method in interface org.apache.hadoop.hbase.client.Table
Increments one or more columns within a single row.
increment(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
increment() - Method in interface org.apache.hadoop.hbase.metrics.Counter
Increment this by 1.
increment(long) - Method in interface org.apache.hadoop.hbase.metrics.Counter
Increment this by n.
increment() - Method in class org.apache.hadoop.hbase.metrics.impl.CounterImpl
 
increment(long) - Method in class org.apache.hadoop.hbase.metrics.impl.CounterImpl
 
increment(Increment) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
increment(Increment, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
increment(Increment, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Perform one or more increment operations on a row.
increment(Increment) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
increment(TIncrement, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
increment(TIncrement, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
increment(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
increment(TIncrement) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Increment a cell by the ammount.
increment - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
The single increment to apply
increment(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
increment(ByteBuffer, TIncrement, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
increment(ByteBuffer, TIncrement, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
increment(ByteBuffer, TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
increment(ByteBuffer, TIncrement) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
 
increment(ByteBuffer, TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
increment() - Method in class org.apache.hadoop.hbase.util.Counter
 
increment() - Method in class org.apache.hadoop.hbase.util.LongAdder
Equivalent to add(1).
INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
INCREMENT_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
 
incrementAppendCount() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Increment the count of wal appends
incrementAppendCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
incrementAppendSize(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Add the append size.
incrementAppendSize(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
incrementAppendTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Add the time it took to append.
incrementAppendTime(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
 
incrementBytes(byte[], long) - Static method in class org.apache.hadoop.hbase.util.Bytes
Bytewise binary increment/deincrement of long contained in byte array on given amount.
IncrementCoalescer - Class in org.apache.hadoop.hbase.thrift
This class will coalesce increments from a thift server if hbase.regionserver.thrift.coalesceIncrement is set to true.
IncrementCoalescer(ThriftServerRunner.HBaseHandler) - Constructor for class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
IncrementCoalescerMBean - Interface in org.apache.hadoop.hbase.thrift
 
incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use HTable.incrementColumnValue(byte[], byte[], byte[], long, Durability).
incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically increments a column value.
incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use Table.incrementColumnValue(byte[], byte[], byte[], long, Durability).
incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
incrementColumnValue(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.client.Table
incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in interface org.apache.hadoop.hbase.client.Table
Atomically increments a column value.
incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
incrementCompactionsQueuedCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
incrementFailedAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementFailedAppendRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number failed append requests.
incrementFailedAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incrementFailedDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementFailedDeleteRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of failed Delete requests.
incrementFailedDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incrementFailedGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementFailedGetRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of failed Get requests.
incrementFailedGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incrementFailedIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementFailedIncrementRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number failed increment requests.
incrementFailedIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incrementFailedPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementFailedPutRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of failed Put Requests.
incrementFailedPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incrementFailedScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementFailedScanRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number failed scan requests.
incrementFailedScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incrementFlushesQueuedCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
incrementFromThrift(TIncrement) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
From a TIncrement create an Increment.
incrementFromThrift(TIncrement) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
 
IncrementingEnvironmentEdge - Class in org.apache.hadoop.hbase.util
Uses an incrementing algorithm instead of the default.
IncrementingEnvironmentEdge() - Constructor for class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
Construct an incremental edge starting from currentTimeMillis
IncrementingEnvironmentEdge(long) - Constructor for class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
Construct an incremental edge with an initial amount
incrementIv(byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
incrementIv(byte[], int) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
incrementLogRollRequested() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
incrementLogRollRequested() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
incrementLowReplicationLogRoll() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
incrementLowReplicationLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
incrementNodeDepthRecursively() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
incrementNumOccurrences(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
Each occurrence > 1 indicates a repeat of the previous entry.
incrementNumOccurrencesOfLatestValue() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
incrementRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
 
incrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of requests
incrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incrementResponseBlockSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
 
incrementResponseBlockSize(long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
incrementResponseCellSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
Add on the given amount to the retained cell size.
incrementResponseCellSize(long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
incrementResponseExceptionSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
 
incrementResponseExceptionSize(long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
incrementRows(List<TIncrement>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
incrementRows(List<TIncrement>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
incrementRows(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
incrementRows(List<TIncrement>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
 
incrementRows(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
increments - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
The list of increments
incrementSlowAppendCount() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Increment the number of appends that were slow
incrementSlowAppendCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
incrementSucessfulAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementSucessfulAppendRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of successful append requests.
incrementSucessfulAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incrementSucessfulDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementSucessfulDeleteRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of successful Delete requests.
incrementSucessfulDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incrementSucessfulGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementSucessfulGetRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of successful Get requests.
incrementSucessfulGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incrementSucessfulIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementSucessfulIncrementRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of successful increment requests.
incrementSucessfulIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incrementSucessfulPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementSucessfulPutRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of successful Put requests.
incrementSucessfulPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incrementSucessfulScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementSucessfulScanRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of successful scan requests.
incrementSucessfulScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incrementSyncTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Add the time it took to sync the wal.
incrementSyncTime(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
incrementTime(long) - Method in class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
Increment the time by the given amount
incrementTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
incrementWrittenBytes(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
incrementWrittenBytes(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
incRequests(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
Increment the number of requests the cluster has seen.
incRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
 
incrFailedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrFailedRecoveryQueue() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrFailedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrFailedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrHedgedReadOps() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of hedged read that have occurred.
incrHedgedReadWin() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of hedged read returned faster than the original read.
incrHFilesShipped(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrHFilesShipped(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrHFilesShipped(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrLogEditsFiltered(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrLogEditsFiltered(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrLogEditsFiltered(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrLogEditsFiltered(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Add on the number of log edits filtered
incrLogEditsFiltered() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
The number of log edits filtered out.
incrLogEditsRead() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Increment the number of log edits read by one.
incrLogReadInBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrLogReadInBytes(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrLogReadInBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrLogReadInBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
increase the byte number read by source from log file
incrLogReadInEdits(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrLogReadInEdits(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrLogReadInEdits(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrMetaCacheHit() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of meta cache hits.
incrMetaCacheMiss() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of meta cache misses.
incrMetaCacheNumClearRegion() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of meta cache drops requested for individual region.
incrMetaCacheNumClearServer() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of meta cache drops requested for entire RegionServer.
incrMiscInvocations() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
 
incrMiscInvocations() - Method in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
 
incrMiscInvocations() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancerSourceImpl
 
incrMiscInvocations() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
 
incrNormalRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Increment the number of normal runner counts.
incrNormalRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
incrOpsShipped(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrOpsShipped(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrOpsShipped(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incRpcCount() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
incrRepeatedFileBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrRepeatedFileBytes(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrRepeatedFileBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrRepeatedFileBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrRestartedWALReading() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrRestartedWALReading() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrRestartedWALReading() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrRestartedWALReading() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrShippedBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrShippedBytes(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrShippedBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrSizeOfHFileRefsQueue(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrSizeOfHFileRefsQueue(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrSizeOfHFileRefsQueue(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrSizeOfHFileRefsQueue(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrSizeOfLogQueue(int) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Increment size of the log queue.
incrSlowAppend() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment the number of slow Appends that have happened.
incrSlowAppend() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
incrSlowDelete() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment the number of slow Deletes that have happened.
incrSlowDelete() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
incrSlowGet() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment the number of slow Gets that have happened.
incrSlowGet() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
incrSlowIncrement() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment the number of slow Increments that have happened.
incrSlowIncrement() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
incrSlowPut() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment the number of slow Puts that have happened.
incrSlowPut() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
incrSplitRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
incrSplitRequest() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment number of a requested splits
incrSplitRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
incrSplitSuccess() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
incrSplitSuccess() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment number of successful splits
incrSplitSuccess() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
incrUncleanlyClosedWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrUncleanlyClosedWALs() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrUncleanlyClosedWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrUncleanlyClosedWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrUnknownFileLengthForClosedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
incrUnknownFileLengthForClosedWAL() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrUnknownFileLengthForClosedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
incrUnknownFileLengthForClosedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
Called when opening a scanner on the data of this MemStoreLAB
incScannerCount() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
Called when opening a scanner on the data of this MemStoreLAB
incSlowCall(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Increment how long a slow call took.
incSlowCall(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
incTimeInQueue(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Add how long an operation was in the queue.
incTimeInQueue(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
incTimeInQueue(long) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
incValue(long) - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
 
incWarnThresholdExceeded(int) - Method in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
Increment the WARN level threshold exceeded count
incWarnThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
incWarnThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
incWarnThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
incWriteFailureCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
 
incWriteFailureCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
 
incWriteSuccessCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
 
incWriteSuccessCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
 
INDEX_COLUMN - Static variable in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
the column family containing the indexed row key
INDEX_KEY_MAGIC - Static variable in class org.apache.hadoop.hbase.HConstants
Used as a magic return value while optimized index key feature enabled(HBASE-7845)
INDEX_QUALIFIER - Static variable in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
the qualifier containing the indexed row key
IndexBuilder - Class in org.apache.hadoop.hbase.mapreduce
Example map/reduce job to construct index tables that can be used to quickly find a row based on the value of a column.
IndexBuilder() - Constructor for class org.apache.hadoop.hbase.mapreduce.IndexBuilder
 
IndexBuilder.Map - Class in org.apache.hadoop.hbase.mapreduce
Internal Mapper to be run by Hadoop.
IndexBuilder.Map() - Constructor for class org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map
 
indexOf(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
Returns the index of the first appearance of the value target in array.
indexOf(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(Object) - Method in class org.apache.hadoop.hbase.util.SortedList
 
indexSize() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
indexSize() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
indexSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
indexWithinComponent - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
 
inferBoundaries(TreeMap<byte[], Integer>) - Static method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
info(String, String) - Static method in class org.apache.hadoop.hbase.metrics.Interns
Get a metric info object
info() - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
 
INFO_THRESHOLD_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
 
INFO_THRESHOLD_COUNT_KEY - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
 
INFO_THRESHOLD_KEY - Static variable in class org.apache.hadoop.hbase.util.JvmPauseMonitor
 
InfoServer - Class in org.apache.hadoop.hbase.http
Create a Jetty embedded server to answer http requests.
InfoServer(String, String, int, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.http.InfoServer
Create a status server on the given port.
infoServer - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
infoServerExists(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Checks whether hbase:meta contains any info:server entry.
INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.Tag
 
init() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Support method to init constants such as timeout.
init(RegionServerServices, Configuration, SplitLogWorker.TaskExecutor, SplitLogWorker) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
Initialize internal values.
init() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
init(RegionServerServices, Configuration, SplitLogWorker.TaskExecutor, SplitLogWorker) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
Override setter from SplitLogWorkerCoordination
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenPresenter
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
 
init() - Method in interface org.apache.hadoop.hbase.hbtop.screen.ScreenView
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenPresenter
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenView
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenPresenter
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.ClickjackingPreventionFilter
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
 
init() - Method in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
Initialize this servlet.
init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.NoCacheFilter
 
init() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
 
init() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
 
init(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
Initialize the key provider
init(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
init(int) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
 
init(int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
 
init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Does some quick initialization.
init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
Build the scanner.
init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
Build the scanner.
init() - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
 
init() - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
Giving a chance for the initialization.
init() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancerSourceImpl
 
init(Map<String, Object>) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
 
init(Map<String, Object>) - Method in interface org.apache.hadoop.hbase.master.cleaner.FileCleanerDelegate
this method is used to pass some instance into subclass
init() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
 
init() - Method in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
 
init() - Method in class org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
 
init() - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
 
init() - Method in class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
 
init(Map<String, Object>) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
 
init() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Clear out the metrics and re-prepare the source.
init() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
init() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
init() - Static method in class org.apache.hadoop.hbase.metrics.impl.GlobalMetricRegistriesAdapter
Make sure that this global MetricSource for hbase-metrics module based metrics are initialized.
init() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
 
init(StoreScanner, AbstractMultiFileWriter.WriterFactory) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
Initializes multi-writer before usage.
init() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySourceImpl
 
init(FileSystem, Path, Configuration, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
init(FileSystem, Path, Configuration, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
init(FileSystem, Path, Configuration, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
init(FileSystem, Path, Configuration, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.WriterBase
 
init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
 
init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
 
init() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
init() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
init() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
 
init(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueues, ReplicationPeers, Stoppable, String, UUID, ReplicationEndpoint, MetricsSource) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
Instantiation method used by region servers
init(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueues, ReplicationPeers, Stoppable, String, UUID, ReplicationEndpoint, MetricsSource) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
Initializer for the source
init() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Adds a normal source per registered peer cluster and tries to process all old region server wal queues
init(ReplicationEndpoint.Context) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Initialize the replication endpoint with the given context.
init() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Initialize the ReplicationPeers interface.
init() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
init(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Initialize the region server replication queue interface.
init() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
Initialize the replication queue client interface.
init() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
init(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
 
init() - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
init() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
init(Configuration, ServiceAuthorizationManager) - Static method in class org.apache.hadoop.hbase.security.HBasePolicyProvider
 
init(Configuration) - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
 
init(RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
init(RegionCoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
System calls this after opening of regions.
init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
init() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
init(Configuration, String) - Method in class org.apache.hadoop.hbase.wal.BoundedGroupingStrategy
 
init(WALFactory, Configuration, List<WALActionsListener>, String) - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
 
init(FileSystem, Path, Configuration, FSDataInputStream) - Method in interface org.apache.hadoop.hbase.wal.DefaultWALProvider.Reader
 
init(FileSystem, Path, Configuration, boolean) - Method in interface org.apache.hadoop.hbase.wal.DefaultWALProvider.Writer
 
init(Configuration, String) - Method in class org.apache.hadoop.hbase.wal.NamespaceGroupingStrategy
 
init(WALFactory, Configuration, List<WALActionsListener>, String) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
init(Configuration, String) - Method in interface org.apache.hadoop.hbase.wal.RegionGroupingProvider.RegionGroupingStrategy
 
init(byte[], TableName, long, long, List<UUID>, long, long, MultiVersionConcurrencyControl) - Method in class org.apache.hadoop.hbase.wal.WALKey
 
init(WALFactory, Configuration, List<WALActionsListener>, String) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
Set up the provider to create wals.
initAdmin() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
initAfterCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
initAfterCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
Initializes the compression after the shared stuff has been initialized.
initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
Initializes the compression after the shared stuff has been initialized.
initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
 
initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
initAfterCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
initAfterHeader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
initAfterHeader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogWriter
 
initCellFilters() - Method in class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
 
initCosts(BaseLoadBalancer.Cluster) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
initCredentials(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
initCredentials(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
 
initCredentialsForCluster(Job, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
initCredentialsForCluster(Job, Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Obtain an authentication token, for the specified cluster, on behalf of the current user and add it to the credentials for the given map reduce job.
initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.FilterInitializer
Initialize a Filter to a FilterContainer.
initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter
 
initFirstNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
INITIAL_MAX_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.io.TimeRange
 
INITIAL_MIN_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.io.TimeRange
 
INITIAL_STRIPE_COUNT_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
The initial stripe count to create.
initialChore() - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
 
initialChore() - Method in class org.apache.hadoop.hbase.ScheduledChore
Override to run a task before we start looping.
initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
initialize(Server) - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
Initialize coordinated state management service.
initialize(Server) - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
 
initialize(Server) - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
initialize(P) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This method should initialize any field(s) of the ColumnInterpreter with a parsing of the passed message bytes (used on the server side).
initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
 
initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Handle subclass specific set up.
initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
 
initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Handle subclass specific set up.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Initializes the reader.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Build the scanner.
initialize(TableSnapshotInputFormatImpl.InputSplit, Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
 
initialize() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
initialize() - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
 
initialize() - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Initialize the load balancer.
initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
initialize() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
Initialize the region assignment snapshot by scanning the hbase:meta table
initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
 
initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
Initialize this region server flush procedure manager Uses a zookeeper based member controller.
initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManager
Initialize a globally barriered procedure for master.
initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
 
initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
Initialize a globally barriered procedure for region servers.
initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
 
initialize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Deprecated.
use HRegion.createHRegion() or HRegion.openHRegion()
initialize(Server, FileSystem, Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
Initializes the replication service object.
initialize(S) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
This method should initialize any field(s) of the RowProcessor with a parsing of the passed message bytes (used on the server side).
initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
Create a default snapshot handler - uses a zookeeper based member controller.
initialize(Server, FileSystem, Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
initialize() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
initialize(Configuration) - Static method in class org.apache.hadoop.hbase.security.Superusers
Should be called only once to pre-load list of super users and super groups from Configuration.
initializeAndGetReadLatencyForTable(String) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
 
initializeCompressionContext(Configuration, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WriterBase
 
initialized - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
initializeQueues(int, Class<? extends BlockingQueue>, Object...) - Method in class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
Deprecated.
initializeQueues(int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to initialize the table information.
initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to initialize the table information.
initializeTagHelpers() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
initializeWriteLatency() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
 
initializeWriter(List<RowNodeWriter>, int, TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
initialSize - Variable in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
 
initJob(String, String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Use this before submitting a TableMap job.
initJob(String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
Use this before submitting a TableMap job.
initJob(String, Scan, String, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Use this before submitting a TableMap job.
initJob(String, Scan, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
Use this before submitting a TableMap job.
initLatch - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
initMultiTableSnapshotMapperJob(Map<String, Collection<Scan>>, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets up the job for reading from one or more multiple table snapshots, with one or more scans per snapshot.
initMultiTableSnapshotMapperJob(Map<String, Collection<Scan>>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets up the job for reading from one or more table snapshots, with one or more scans per snapshot.
initMultiWriter(AbstractMultiFileWriter, InternalScanner, Compactor.FileDetails, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.AbstractMultiOutputCompactor
 
initOnBlock(PrefixTreeBlockMeta, byte[]) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
initOnBlock(PrefixTreeBlockMeta, byte[]) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
 
initOnBlock(PrefixTreeBlockMeta, byte[], boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
initOnBlock(PrefixTreeBlockMeta, byte[], int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
construct
initOnBlock(PrefixTreeBlockMeta, byte[]) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.MvccVersionDecoder
 
initOnBlock(PrefixTreeBlockMeta, byte[]) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.TimestampDecoder
 
initOnBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
initReader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
initReader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
Initializes the log reader with a particular stream (may be null).
initReader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
initSaslProperties(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
 
initScanMetrics(Scan) - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
Check and initialize if application wants to collect scan metrics
initSource() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
A function to instantiate the metrics source.
initSource() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
This function overrides the initSource in the MetricsBalancer, use MetricsStochasticBalancerSource instead of the MetricsBalancerSource.
initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(TableName, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a Multi TableMap job.
initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a Multi TableMap job.
initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a Multi TableMap job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job, Class) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
injectEdge(EnvironmentEdge) - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
Injects the given edge such that it becomes the managed entity.
injectNonceGeneratorForTesting(ClusterConnection, NonceGenerator) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
 
InlineBlockWriter - Interface in org.apache.hadoop.hbase.io.hfile
A way to write "inline" blocks into an HFile.
inMemory - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
INMEMORY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
INPUT_AUTOBALANCE_MAXSKEWRATIO - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Deprecated.
INPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Job parameter that specifies the input table.
InputModeScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.top
The presentation logic for the input mode.
InputModeScreenPresenter(InputModeScreenView, String, List<String>, InputModeScreenPresenter.ResultListener) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
InputModeScreenPresenter.ResultListener - Interface in org.apache.hadoop.hbase.hbtop.screen.top
 
InputModeScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.top
The input mode in the top screen.
InputModeScreenView(Screen, Terminal, int, String, List<String>, InputModeScreenPresenter.ResultListener) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
 
inputStream - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
inputStreamFromByteRange(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.types.PBType
Create a CodedInputStream from a PositionedByteRange.
insert(Procedure, Procedure[]) - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
 
insert(Procedure, Procedure[]) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
When a procedure is submitted to the executor insert(proc, null) will be called.
insert(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
insert(long, long[]) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
insert(Procedure, Procedure[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
insert(long) - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
Add a new value from the stream.
insertDataValue(long) - Method in class org.apache.hadoop.hbase.util.RollingStatCalculator
Inserts given data value to array of data values to be considered for statistics calculation
insertIntoNSTable(MasterProcedureEnv, NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
Insert the row into ns table
insertIntoNSTable(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
insertNewFiles(Collection<StoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Adds new files, either for from MemStore flush or bulk insert, into the structure.
insertNewFiles(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
insideBarrier() - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
 
insideBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
The implementation of this method should act with the assumption that the barrier condition has been satisfied.
insideBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
 
insideBarrier() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
do a flush snapshot of every region on this rs from the target table.
install(Configuration, FileSystem, Stoppable, Thread) - Static method in class org.apache.hadoop.hbase.regionserver.ShutdownHook
Install a shutdown hook that calls stop on the passed Stoppable and then thread joins against the passed threadToJoin.
installed - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
 
INSTANCE - Static variable in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
INSTANCE - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
 
instance - Static variable in class org.apache.hadoop.hbase.zookeeper.EmptyWatcher
 
instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
instantiate(Configuration, ServerStatisticTracker) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
instantiate(Configuration, RetryingCallerInterceptor, ServerStatisticTracker) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.security.UserProvider
Instantiate the UserProvider specified in the configuration and set the passed configuration via UserProvider.setConf(Configuration)
instantiateBlockCache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Returns the block cache or null in case none should be used.
instantiated - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
instantiateDeleteTracker(RegionCoprocessorHost) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
instantiateFilter(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Create a Filter to apply to all incoming keys (KeyValues) to optionally not include in the job output
instantiateHStore(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
instantiateRegionScanner(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
instantiateRegionScanner(Scan, List<KeyValueScanner>, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
instantiateWithCustomCtor(String, Class<?>[], Object[]) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
 
INT_7_RIGHT_BITS_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVIntTool
 
INT_8TH_BIT_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVIntTool
 
INTEGER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for an Integer
InterfaceAudience - Class in org.apache.hadoop.hbase.classification
Annotation to inform users of a package, class or method's intended audience.
InterfaceAudience.LimitedPrivate - Annotation Type in org.apache.hadoop.hbase.classification
Intended only for the project(s) specified in the annotation.
InterfaceAudience.Private - Annotation Type in org.apache.hadoop.hbase.classification
Intended for use only within Hadoop itself.
InterfaceAudience.Public - Annotation Type in org.apache.hadoop.hbase.classification
Intended for use by any project or application.
InterfaceStability - Class in org.apache.hadoop.hbase.classification
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
InterfaceStability() - Constructor for class org.apache.hadoop.hbase.classification.InterfaceStability
 
InterfaceStability.Evolving - Annotation Type in org.apache.hadoop.hbase.classification
Evolving, but can break compatibility at minor release (i.e.
InterfaceStability.Stable - Annotation Type in org.apache.hadoop.hbase.classification
Can evolve while retaining compatibility for minor release boundaries.; can break compatibility only at major release (ie.
InterfaceStability.Unstable - Annotation Type in org.apache.hadoop.hbase.classification
No guarantee is provided as to reliability or stability across any level of release granularity.
internalClose() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
 
internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
 
internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
 
internalEncode(Cell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
internalEncode(Cell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
 
internalEncode(Cell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
 
internalEncode(Cell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
 
internalFlushcache(WAL, long, Collection<Store>, MonitoredTask, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Flush the memstore.
internalFlushCacheAndCommit(WAL, MonitoredTask, HRegion.PrepareFlushResult, Collection<Store>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
 
internalPrepareFlushCache(WAL, long, Collection<Store>, MonitoredTask, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
InternalScan - Class in org.apache.hadoop.hbase.regionserver
Special scanner, currently used for increment operations to allow additional server-side arguments for Scan operations.
InternalScan(Get) - Constructor for class org.apache.hadoop.hbase.regionserver.InternalScan
 
InternalScan(Scan) - Constructor for class org.apache.hadoop.hbase.regionserver.InternalScan
 
InternalScanner - Interface in org.apache.hadoop.hbase.regionserver
Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[] instead of RowResults.
Interns - Class in org.apache.hadoop.hbase.metrics
Helpers to create interned metrics info
InterProcessLock - Interface in org.apache.hadoop.hbase
An interface for an application-specific lock.
InterProcessLock.MetadataHandler - Interface in org.apache.hadoop.hbase
An interface for objects that process lock metadata.
InterProcessReadWriteLock - Interface in org.apache.hadoop.hbase
An interface for a distributed reader-writer lock.
interrupt() - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
 
interrupt() - Method in class org.apache.hadoop.hbase.util.HasThread
 
interruptedException(InterruptedException) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Handles InterruptedExceptions in client calls.
interruptedExceptionNoThrow(InterruptedException, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Log the InterruptedException and interrupt current thread
intFitsIn(int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Check how many bytes is required to store value.
intValue() - Method in class org.apache.hadoop.hbase.util.LongAdder
Returns the LongAdder.sum() as an int after a narrowing primitive conversion.
INVALID_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
Constant to denote invalid hash type.
INVALID_REGION_NAME_FORMAT_MESSAGE - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
invalidate() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
InvalidFamilyOperationException - Exception in org.apache.hadoop.hbase
Thrown if a request is table schema modification is requested but made for an invalid family name.
InvalidFamilyOperationException() - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
default constructor
InvalidFamilyOperationException(String) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
Constructor
InvalidFamilyOperationException(Exception) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
Constructor taking another exception.
InvalidHFileException - Exception in org.apache.hadoop.hbase.io.hfile
Thrown when an invalid HFile format is detected
InvalidHFileException() - Constructor for exception org.apache.hadoop.hbase.io.hfile.InvalidHFileException
constructor
InvalidHFileException(String) - Constructor for exception org.apache.hadoop.hbase.io.hfile.InvalidHFileException
Constructor
InvalidLabelException - Exception in org.apache.hadoop.hbase.security.visibility
 
InvalidLabelException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.InvalidLabelException
 
InvalidQuotaSettingsException - Exception in org.apache.hadoop.hbase.quotas
Generic quota exceeded exception for invalid settings
InvalidQuotaSettingsException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.InvalidQuotaSettingsException
 
InvalidRowFilterException - Exception in org.apache.hadoop.hbase.filter
Used to indicate an invalid RowFilter.
InvalidRowFilterException() - Constructor for exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
constructor
InvalidRowFilterException(String) - Constructor for exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
constructor
invert(float[][]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
Copy a given matrix into a new matrix, transforming each row index and each column index according to the inverse of the randomization scheme that was created at construction time.
invertIndices(int[]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
Given an array where each element indices[i] represents the randomized column index corresponding to randomized row index i, create a new array with the corresponding inverted indices.
invoke(Object, Method, Object[]) - Method in class org.apache.hadoop.hbase.thrift.HbaseHandlerMetricsProxy
 
invokeAssign(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
invokeAssign(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
IO_STOREFILE_BLOOM_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
Target Bloom block size.
IO_STOREFILE_BLOOM_ENABLED - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
Master switch to enable Bloom filters
IO_STOREFILE_BLOOM_ERROR_RATE - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
Specifies the target error rate to use when selecting the number of keys per Bloom filter.
IO_STOREFILE_BLOOM_MAX_FOLD - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
Maximum folding factor allowed.
IO_STOREFILE_BLOOM_MAX_KEYS - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
For default (single-block) Bloom filters this specifies the maximum number of keys.
IO_STOREFILE_DELETEFAMILY_BLOOM_ENABLED - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
Master switch to enable Delete Family Bloom filters
IOEngine - Interface in org.apache.hadoop.hbase.io.hfile.bucket
A class implementing IOEngine interface supports data services for BucketCache.
IOError - Exception in org.apache.hadoop.hbase.thrift.generated
 
IOError() - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IOError
 
IOError(String) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IOError
 
IOError(IOError) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IOError
Performs a deep copy on other.
IOError._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ioHit(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
 
IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_DEFAULT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_KEY - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
IPC_SERVER_MAX_CALLQUEUE_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcScheduler
 
IPC_SERVER_PRIORITY_MAX_CALLQUEUE_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcScheduler
 
is32BitJVM() - Static method in class org.apache.hadoop.hbase.util.ClassSize
Determines if we are running in a 32-bit JVM.
IS_ACTIVE_MASTER_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
IS_ACTIVE_MASTER_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
IS_META - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by rest interface to access this metadata attribute which denotes if it is a catalog table, either hbase:meta or -ROOT-
IS_ROOT - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by rest interface to access this metadata attribute which denotes if the table is a -ROOT- region or not
isAborted() - Method in interface org.apache.hadoop.hbase.Abortable
Check if the server or client was aborted.
isAborted() - Method in interface org.apache.hadoop.hbase.client.Admin
 
isAborted() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isAborted() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
isAborted() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
isAborted() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner.WarnOnlyAbortable
 
isAborted() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
isAborted() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
isAbortPathNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
Is this in the procedure barrier abort znode path
isAcceptableAddress(InetAddress) - Method in interface org.apache.hadoop.hbase.util.Addressing.AddressSelectionCondition
Condition on which to accept inet address
isAccessControllerRunning(Connection) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
 
isAccessControllerRunning(Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
isActiveMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
Report whether this master is currently the active master or not.
isAfterLast() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
isAlive() - Method in class org.apache.hadoop.hbase.http.HttpServer
Test for the availability of the web server
isAlive() - Method in class org.apache.hadoop.hbase.util.HasThread
 
isAllFiles() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
isAllowed() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
isAllSameMvccVersion() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
isAllSameTimestamp() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
isAllSameType() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
isAllTime() - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if it is for all time
isAlt() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
 
isAmd64() - Static method in class org.apache.hadoop.hbase.util.JVM
Check if the arch is amd64;
isAnyMetaReplicaZnode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Is the znode of any meta replica
isAppendSupported(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Heuristic to determine whether is safe or not to open a file for append Looks both for dfs.support.append and use reflection to search for SequenceFile.Writer.syncFs() or FSDataOutputStream.hflush()
isAscendingOrder() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
isAuthorizationEnabled(Connection) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Return true if authorization is supported and enabled
isAuthorizationSupported(Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessChecker
 
isAuthorizationSupported(Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessController
 
isAuthorizationSupported(Configuration) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
isAutoAdjust() - Method in enum org.apache.hadoop.hbase.hbtop.field.Field
 
isAutoFlush() - Method in class org.apache.hadoop.hbase.client.HTable
Tells whether or not 'auto-flush' is turned on.
isAutoFlush() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
as of 1.0.0. Replaced by BufferedMutator
isAutoFlush() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
isAutoFlush() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
isAvailable() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler.TableQueue
 
isAvailable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isAvailable() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
isAvailable() - Static method in class org.apache.hadoop.hbase.util.UnsafeAvailChecker
 
isBackReferencesDir(Path) - Static method in class org.apache.hadoop.hbase.io.FileLink
Checks if the specified directory path is a back reference links folder.
isBadJvmVersion() - Static method in class org.apache.hadoop.hbase.util.JvmVersion
Return true if the current JVM is known to be unstable.
isBalancerEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query the current state of the balancer
isBalancerEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Query the state of the balancer from the Master.
isBalancerEnabled(RpcController, MasterProtos.IsBalancerEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
isBalancerOn() - Method in class org.apache.hadoop.hbase.master.HMaster
Queries the state of the LoadBalancerTracker.
isBalancerOn() - Method in class org.apache.hadoop.hbase.zookeeper.LoadBalancerTracker
Return true if the balance switch is on, false otherwise
isBeforeFirst() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
isBlink() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
isBlink() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
isBlobCopy(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses BlobCopy encoding, false otherwise.
isBlobVar(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses BlobVar encoding, false otherwise.
isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Checks whether the block cache is enabled.
isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
isBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
isBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
isBranch() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
isBranch() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
isBranch() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
isBrowser(String) - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
This method interrogates the User-Agent String and returns whether it refers to a browser.
isBulkLoaded() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
isBulkLoadResult() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
Check if this storefile was created by bulk load.
isBypass() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
 
isBypass() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
 
isBypass() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
 
isBypass() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
 
isBypass() - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
 
isCacheBlocks() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
isCacheBlocks() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
isCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheDataInL1() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheDataInL1() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
isCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCallDroppedException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Checks if the exception is CallDroppedException (maybe wrapped into some RemoteException).
isCallQueueTooBigException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Checks if the exception is CallQueueTooBig exception (maybe wrapped into some RemoteException).
isCanceled() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
isCanceled() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
isCanceled() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
isCancelled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
isCancelled() - Method in class org.apache.hadoop.hbase.client.PayloadCarryingServerCallable
 
isCancelled() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
isCarryingMeta(ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
isCarryingMetaReplica(ServerName, int) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
isCarryingMetaReplica(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
isCatalogJanitorEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query on the catalog janitor state (Enabled/Disabled?)
isCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Query on the catalog janitor state (Enabled/Disabled?)
isCatalogJanitorEnabled(RpcController, MasterProtos.IsCatalogJanitorEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isCellAuthorizationEnabled(Connection) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Return true if cell authorization is supported and enabled
isCellAuthorizationSupported(Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessController
 
isCellAuthorizationSupported(Configuration) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
isCellTTLExpired(Cell, long, long) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
 
isCellVisibilityEnabled(Connection) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
Return true if cell visibility features are supported and enabled
isCheckExistenceOnly() - Method in class org.apache.hadoop.hbase.client.Get
 
isCheckOnlyMemStore() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
Returns true if only the MemStore should be checked.
isCheckOnlyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
Returns true if only StoreFiles should be checked.
isChildOfSameType(String) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Check if a child znode represents the same type(read or write) of lock
isChildReadLock(String) - Static method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Check if a child znode represents a read lock.
isChildWriteLock(String) - Static method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Check if a child znode represents a write lock.
isChoreScheduled(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
 
isClassExempt(String, String[]) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
Determines whether the given class should be exempt from being loaded by this ClassLoader.
isCleanerChoreEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query on the cleaner chore state (Enabled/Disabled?)
isCleanerChoreEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isCleanerChoreEnabled(RpcController, MasterProtos.IsCleanerChoreEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isClientCellBlockSupported() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
If the client connected and specified a codec to use, then we will use this codec making cellblocks to return.
isClientCellBlockSupported() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
isClientReadable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Returns whether the znode is supposed to be readable by the client and DOES NOT contain sensitive information (world readable).
isClosed() - Method in interface org.apache.hadoop.hbase.client.Connection
Returns whether the connection is closed or not.
isClosed() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
 
isClosed() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isClosed(AdminProtos.CloseRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Check if the region is closed from a CloseRegionResponse
isClosed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isClosed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
isClosestRowBefore() - Method in class org.apache.hadoop.hbase.client.Get
 
isClosing() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isClosing() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isClosing() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
isClusterShutdown() - Method in class org.apache.hadoop.hbase.master.ServerManager
 
isClusterUp() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
Checks if cluster is up.
isCodelQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
isColumnSorted() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.ResultScannerWrapper
 
isCompacted() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
isCompactedAway() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
isCompactedAway() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
isCompaction - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
isCompactionEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Check if the compaction enable flag of the table is true.
isCompactionMarker(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
Returns true if the given cell is a serialized WALProtos.CompactionDescriptor
isCompactionNeeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
Convenience method, the equivalent of checking if result is FLUSHED_COMPACTION_NEEDED.
isCompactionNeeded() - Method in interface org.apache.hadoop.hbase.regionserver.Region.FlushResult
 
isComplete() - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
isCompleted(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
 
isCompleted() - Method in class org.apache.hadoop.hbase.procedure.Procedure
Check if the entire procedure has globally completed, or has been aborted.
isCompletelyFree() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
isCompressedOrEncrypted() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
isCompressTags() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isCompressTags() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
isConnectionException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Check if the exception is something that indicates that we cannot contact/communicate with the server.
isCorrectEncoder(DataBlockEncoder, short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Check if given encoder has this id.
isCorrupted(Path, String, FileSystem) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
iscreate(InputStream) - Static method in class org.apache.hadoop.hbase.KeyValue
iscreate(InputStream, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue reading from the raw InputStream.
isCtrl() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
 
isCursor() - Method in class org.apache.hadoop.hbase.client.Result
Return true if this Result is a cursor to tell users where the server has scanned.
isData() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
 
isDead - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
 
isDeadlineQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
isDeadServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Deprecated.
internal method, do not use thru HConnection
isDeadServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
isDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
 
isDefaultMetaReplicaZnode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Is it the default meta replica's znode
isDefaultReplica(int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
 
isDefaultReplica(HRegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
 
isDelete(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDelete(byte) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDelete(byte) - Static method in class org.apache.hadoop.hbase.KeyValue
 
isDelete() - Method in class org.apache.hadoop.hbase.KeyValue
Deprecated.
isDelete - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
isDeleteColumnOrFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDeleteColumns(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDeleteColumnVersion(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDeleted(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
isDeleted(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
isDeleted(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
Check if the specified cell buffer has been deleted by a previously seen delete.
isDeleted(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
Check if the specified KeyValue buffer has been deleted by a previously seen delete.
isDeleted(Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
 
isDeleteFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDeleteFamilyBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
 
isDeleteFamilyVersion(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDeleteType(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
isDirectlyAfterNub() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayReversibleScanner
 
isDirectory(FileSystem, Boolean, Path) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
 
isDisabledTable(ZooKeeperWatcher, TableName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLED.
isDisablingOrDisabledTable(ZooKeeperWatcher, TableName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLING of ZooKeeperProtos.Table.State#DISABLED.
isDisplayByDefault() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldInfo
 
isDistributedFileSystem(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
isDone() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
isDone() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
isDone(long) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
Give the tracker a chance to declare it's done based on only the timestamp to allow an early out.
isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
 
isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
 
isDone(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isDone() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isDone() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
isDoNotRetry() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
isEmpty() - Method in class org.apache.hadoop.hbase.client.Mutation
Method to check if the familyMap is empty
isEmpty() - Method in class org.apache.hadoop.hbase.client.Result
Check if the underlying Cell [] is empty or not
isEmpty() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
isEmpty() - Method in class org.apache.hadoop.hbase.hbtop.Record
 
isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
isEmpty() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
isEmpty() - Method in class org.apache.hadoop.hbase.master.DeadServer
 
isEmpty() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
isEmpty() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
isEmpty(String) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
 
isEmpty() - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
 
isEmpty() - Method in class org.apache.hadoop.hbase.RegionLocations
Returns whether there are non-null elements in the list
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
isEmpty() - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
 
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Checks whether the map is currently empty.
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
isEmpty() - Method in class org.apache.hadoop.hbase.rest.client.Cluster
 
isEmpty() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
isEmpty() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
isEmpty() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
isEmpty(ByteRange) - Static method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
isEmpty(byte[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
 
isEmpty(long[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
 
isEmpty(Object[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
 
isEmpty() - Method in interface org.apache.hadoop.hbase.util.ByteRange
 
isEmpty(Collection<T>) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
empty
isEmpty() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
isEmpty() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
isEmpty() - Method in class org.apache.hadoop.hbase.util.SortedList
 
isEmpty(String) - Static method in class org.apache.hadoop.hbase.util.Strings
Null-safe length check.
isEmpty() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
Deprecated.
 
isEmptyQuota(QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
If throttling is enabled
isEnabledTable(ZooKeeperWatcher, TableName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#ENABLED.
isEncodedValue(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Returns true when src appears to be positioned an encoded value, false otherwise.
isEndOfLine() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
isErr(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isErr() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isError - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
isEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isExclusive() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Only one instance of hbck can modify HBase at a time.
isExistingSource() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
Returns whether or not this MetricRegistry is for an existing BaseSource
isExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Calls fs.exists().
isFailed() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
isFailed() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
isFailedClose() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isFailedOpen() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isFailedServer(InetSocketAddress) - Method in class org.apache.hadoop.hbase.ipc.FailedServers
Check if the server should be considered as bad.
isFailoverCleanupDone() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Used by ServerShutdownHandler to make sure AssignmentManager has completed the failover cleanup before re-assigning regions of dead servers.
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.Filter
Check that given column family is essential for filter to check row.
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterBase
By default, we require all scan's column families to be present.
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
The only CF this filter needs is given column family.
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
isFifoQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
isFile(FileSystem, Boolean, Path) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
Should the master delete the file or keep it?
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseLogCleanerDelegate
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
 
isFileInfoLoaded() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
isFileInfoLoaded() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
isFileScanner() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
 
isFileScanner() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
 
isFileScanner() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
isFilterDone() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
 
isFinished() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
 
isFinished() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
 
isFinished() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
isFinished() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
Check to see if the snapshot is finished, where finished may be success or failure.
isFinished() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
isFinished(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Return true if the procedure is finished.
isFirstCellInRow() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
isFixedFloat32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Float32 encoding, false otherwise.
isFixedFloat64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Float64 encoding, false otherwise.
isFixedInt16(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Int16 encoding, false otherwise.
isFixedInt32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Int32 encoding, false otherwise.
isFixedInt64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Int64 encoding, false otherwise.
isFixedInt8(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses fixed-width Int8 encoding, false otherwise.
isFlushSucceeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
Convenience method, the equivalent of checking if result is FLUSHED_NO_COMPACTION_NEEDED or FLUSHED_NO_COMPACTION_NEEDED.
isFlushSucceeded() - Method in interface org.apache.hadoop.hbase.regionserver.Region.FlushResult
 
isFull() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
 
isFullServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
isGeneralBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
 
isGet() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
 
isGet() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
 
isGet() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
isGetScan() - Method in class org.apache.hadoop.hbase.client.Scan
 
isGlobal() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
Returns true if this permission describes a global user permission.
isGroupPrincipal(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
Returns whether or not the given name should be interpreted as a group principal.
isGuaranteedClientSideOnly() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
isGZIPOutputStreamFinishBroken() - Static method in class org.apache.hadoop.hbase.util.JVM
Check if the finish() method of GZIPOutputStream is broken
isHadoopSecurityEnabled() - Method in class org.apache.hadoop.hbase.security.UserProvider
 
isHashCached() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
isHBaseSecurityEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.security.User
Returns whether or not secure authentication is enabled for HBase.
isHBaseSecurityEnabled() - Method in class org.apache.hadoop.hbase.security.UserProvider
 
isHDFS(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
isHFile() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
isHFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isHFile(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isHFileFormat(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Returns true if the specified file has a valid HFile Trailer.
isHFileFormat(FileSystem, FileStatus) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Returns true if the specified file has a valid HFile Trailer.
isHFileLink(Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
 
isHFileLink(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
 
isHttpEnabled() - Method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
 
isHttpsEnabled() - Method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
 
isIncludesMvcc() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
isIncludesMvccVersion() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
isIncludesTags() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
isInitialChoreComplete() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
isInitializationStartsMetaRegionAssignment() - Method in class org.apache.hadoop.hbase.master.HMaster
Report whether this master has started initialization and is about to do meta region assignment
isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.master.HMaster
Report whether this master has completed with its initialization and is ready.
isInitialized() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
isInitialized() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
isInitialized() - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
Checks if namespace auditor is initialized.
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
isInMaintenanceMode() - Method in class org.apache.hadoop.hbase.master.HMaster
Report whether this master is in maintenance mode.
isInMaintenanceMode() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
isInMaintenanceMode() - Method in class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
 
isInMemory() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isInMemory() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
isInMemory() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
isInReturnCodes(Filter.ReturnCode, Filter.ReturnCode...) - Static method in class org.apache.hadoop.hbase.filter.FilterListBase
 
isInRpcCallContext() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
 
isInstrumentationAccessAllowed(ServletContext, HttpServletRequest, HttpServletResponse) - Static method in class org.apache.hadoop.hbase.http.HttpServer
Checks the user has privileges to access to instrumentation servlets.
isInterrupt(Throwable) - Static method in class org.apache.hadoop.hbase.util.ExceptionUtil
 
isInterrupted() - Method in class org.apache.hadoop.hbase.util.HasThread
 
isIsDelete() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
isLastCellInRow() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
isLastIndex(List<?>, int) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
 
isLatestTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue
 
isLeaf() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
isLeaf() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
methods
isLeaf() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
isLeftJustify() - Method in enum org.apache.hadoop.hbase.hbtop.field.Field
 
isLegalFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isLegalFullyQualifiedTableName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
Check passed byte array, "tableName", is legal user-space table name.
isLegalNamespaceName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
 
isLegalNamespaceName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
Valid namespace characters are [a-zA-Z_0-9]
isLegalTableQualifierName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
 
isLegalTableQualifierName(byte[], boolean) - Static method in class org.apache.hadoop.hbase.TableName
 
isLegalTableQualifierName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
Qualifier names can only contain 'word' characters [a-zA-Z_0-9] or '_', '.' or '-'.
isLegalTableQualifierName(byte[], int, int, boolean) - Static method in class org.apache.hadoop.hbase.TableName
 
isLink() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isLinux() - Static method in class org.apache.hadoop.hbase.util.JVM
Check if the OS is linux.
isLoadingCfsOnDemandDefault() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isLoadingCfsOnDemandDefault() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
isLocal(Configuration) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
isLocalAddress(InetAddress) - Static method in class org.apache.hadoop.hbase.util.Addressing
Given an InetAddress, checks to see if the address is a local address, by comparing the address with all the interfaces on the node.
isLocationAvailable(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Checks if the meta region location is available.
isLogDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseLogCleanerDelegate
Deprecated.
isLogDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
 
isLogReplaying() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
 
isLogSplitting() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
 
isMajor() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
isMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
isMajorCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
isMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
isManaged() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
isMaster() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
isMasterInMaintenanceMode() - Method in interface org.apache.hadoop.hbase.client.Admin
Check whether Master is in maintenance mode
isMasterInMaintenanceMode() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isMasterInMaintenanceMode(RpcController, MasterProtos.IsInMaintenanceModeRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Deprecated.
this has been deprecated without a replacement
isMasterRunning() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
this has been deprecated without a replacement
isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
isMasterRunning(RpcController, MasterProtos.IsMasterRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isMatch() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
methods
isMatchingTail(Path, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Compare path component of the Path URI; e.g.
isMatchingTail(Path, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Compare path component of the Path URI; e.g.
isMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
isMergeable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isMerged() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isMerged() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
isMerging() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isMergingNew() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isMetaClearingException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
 
isMetaEdit() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
isMetaEditFamily(byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
isMetaEditFamily(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
isMetaFile(Path) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
 
isMetaFile(String) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
 
isMetaRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isMetaRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Checks if this table is hbase:meta region.
isMetaRegionInTransition() - Method in class org.apache.hadoop.hbase.master.RegionStates
 
isMetaTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isMetaTable() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Checks if the table is a hbase:meta table
isMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
isNamespaceEntry(String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
 
isNamespaceEntry(byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
 
isNamespaceRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isNeedCursorResult() - Method in class org.apache.hadoop.hbase.client.Scan
 
isNextCompleted() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureIterator
 
isNormalizationEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Check if normalization enable flag of the table is true.
isNormalizerEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
Query the current state of the region normalizer
isNormalizerEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Query the current state of the region normalizer
isNormalizerEnabled(RpcController, MasterProtos.IsNormalizerEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isNormalizerOn() - Method in class org.apache.hadoop.hbase.master.HMaster
Queries the state of the RegionNormalizerTracker.
isNormalizerOn() - Method in class org.apache.hadoop.hbase.zookeeper.RegionNormalizerTracker
Return true if region normalizer is on, false otherwise
isNub() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
isNub() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
isNub() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
isNull() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
 
isNull(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src is null, false otherwise.
isNullable() - Method in interface org.apache.hadoop.hbase.types.DataType
Indicates whether this instance supports encoding null values.
isNullable() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
isNullable() - Method in class org.apache.hadoop.hbase.types.PBType
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawByte
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawLong
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawShort
 
isNullable() - Method in class org.apache.hadoop.hbase.types.RawString
 
isNullable() - Method in class org.apache.hadoop.hbase.types.Struct
 
isNullable() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
isNullable() - Method in class org.apache.hadoop.hbase.types.Union2
 
isNullable() - Method in class org.apache.hadoop.hbase.types.Union3
 
isNullable() - Method in class org.apache.hadoop.hbase.types.Union4
 
isNumeric(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Numeric encoding, false otherwise.
isNumericInfinite(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Numeric encoding and is Infinite, false otherwise.
isNumericNaN(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Numeric encoding and is NaN, false otherwise.
isNumericZero(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Numeric encoding and is 0, false otherwise.
isOffline() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOffline() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
isOffPeak() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
isOffPeakHour(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
 
isOffPeakHour() - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
 
IsolationLevel - Enum in org.apache.hadoop.hbase.client
Specify Isolation levels in Scan operations.
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.append
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.atomicIncrement
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.checkAndPut
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.compact
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.createTable
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAll
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllRow
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllRowTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteTable
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.disableTable
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.enableTable
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.get
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getColumnDescriptors
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRegionInfo
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRow
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowOrBefore
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRows
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsWithColumns
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsWithColumnsTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowWithColumns
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowWithColumnsTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getTableNames
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getTableRegions
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getVer
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getVerTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.increment
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.incrementRows
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.isTableEnabled
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.majorCompact
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRow
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRows
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRowsTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRowTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerClose
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerGet
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerGetList
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpen
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithPrefix
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithScan
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithStop
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithStopTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.append
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.atomicIncrement
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.checkAndPut
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.compact
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.createTable
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAll
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRow
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRowTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteTable
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.disableTable
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.enableTable
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.get
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getColumnDescriptors
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRegionInfo
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRow
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowOrBefore
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRows
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumns
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumnsTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumns
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumnsTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableNames
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableRegions
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVer
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVerTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.increment
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.incrementRows
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.isTableEnabled
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.majorCompact
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRow
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRows
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowsTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerClose
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGet
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGetList
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpen
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithPrefix
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithScan
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStop
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStopTs
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.append
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndDelete
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndMutate
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndPut
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.closeScanner
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.deleteMultiple
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.deleteSingle
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.exists
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.get
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getAllRegionLocations
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getMultiple
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getRegionLocation
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getScannerResults
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getScannerRows
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.increment
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.mutateRow
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.openScanner
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.put
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.putMultiple
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.append
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndDelete
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndMutate
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndPut
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.closeScanner
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteMultiple
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteSingle
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.exists
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.existsAll
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.get
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getAllRegionLocations
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getMultiple
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getRegionLocation
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerResults
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerRows
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.increment
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.mutateRow
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.openScanner
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.put
 
isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.putMultiple
 
isOnLastFanNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
isOnline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Report the status of the server.
isOnline() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
isOnline() - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Whether the manager is able to fully return group metadata
isOnline() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
isOnlineSchemaChangeAllowed(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterDDLOperationHelper
Check whether online schema change is allowed from config
isOnlineSchemaChangeSupported() - Method in enum org.apache.hadoop.hbase.executor.EventType
 
isOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpened() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpening() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpenOrMergingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpenOrMergingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpenOrSplittingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOpenOrSplittingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOperationRunning() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
 
isOperationRunning() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
Indicates to the client whether this task is monitoring a currently active RPC call to a database command.
isOrderPreserving() - Method in interface org.apache.hadoop.hbase.types.DataType
Indicates whether this instance writes encoded byte[]'s which preserve the natural sort order of the unencoded value.
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.PBType
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawByte
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawLong
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawShort
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawString
 
isOrderPreserving - Variable in class org.apache.hadoop.hbase.types.Struct
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Struct
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union2
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union3
 
isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union4
 
isOrphan() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
isOutOfBounds() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
isOwned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isOwned() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isPartial() - Method in class org.apache.hadoop.hbase.client.Result
Deprecated.
the word 'partial' ambiguous, use Result.mayHaveMoreCellsInRow() instead. Deprecated since 1.4.0.
isPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
isPBMagicPrefix(byte[], int, int) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
isPeerEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
 
isPeerEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
check whether the peer is enabled or not
isPeerPath(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
Determine if a ZK path points to a peer node.
isPendingClose() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPendingCloseOrClosing() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPendingCloseOrClosingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPendingOpen() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPendingOpenOrOpening() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPendingOpenOrOpeningOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
isPeriodic() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
isPersistent() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
Memory IO engine is always unable to support persistent storage for the cache
isPersistent() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
File IO engine is always able to support persistent storage for the cache
isPersistent() - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
 
isPrefetchBlocksOnOpen() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isPrimary() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
isPrimaryReplicaReader() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
isPrimaryReplicaReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
isPrimaryReplicaReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
isPrimaryReplicaStore() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
isPrimaryReplicaStore() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
isProcedureDone(RpcController, MasterProtos.IsProcedureDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Checks if the specified procedure is done.
isProcedureDone(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
isProcedureDone(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
 
isProcedureDone(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManager
Check if the procedure is finished successfully
isProcedureFinished(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Check the current state of the specified procedure.
isProcedureFinished(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Check the current state of the specified procedure.
isProcedureOwner(long, User) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Check if the user is this procedure's owner
isProcedureOwner(ProcedureInfo, User) - Static method in class org.apache.hadoop.hbase.ProcedureInfo
Check if the user is this procedure's owner
isProcessingServer(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
 
isPublishStatusInZk() - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
 
isQueueRecovered() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
 
isQuotaEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
Returns true if the support for quota is enabled
isQuotaEnabled() - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
 
isQuotaInitialized() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
isQuoteUnescaped(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns a boolean indicating whether the quote was escaped or not
isRaw() - Method in class org.apache.hadoop.hbase.client.Scan
 
isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.consumer.ProtobufMessageBodyConsumer
 
isReaderRunning() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReaderThread
 
isReadFromSystemAuthUser() - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
isReadOnly() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Check if the readOnly flag of the table is set.
isReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isReadOnly() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
isReadOnly(HRegion) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
Returns whether this region replica can accept writes.
isReadSuccess() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
isReady() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
Check whether the log splitter is ready to supply tasks
isReady() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
 
isReady() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler.ProcedureEvent
 
isReadyToOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
Check if a region state can transition to offline
isReadyToOnline() - Method in class org.apache.hadoop.hbase.master.RegionState
Check if a region state can transition to online
isRecoveredEdits(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Checks if the given path is the one with 'recovered.edits' dir.
isRecovering() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isRecovering() - Method in interface org.apache.hadoop.hbase.regionserver.Region
 
isRecoverySupported() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
isReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
isReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isReference(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isReference(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isReferencedInReads() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
isRegionCached(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
Check the region cache to see whether a region is cached yet or not.
isRegionInRegionStates(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
isRegionInServerManagerStates(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
isRegionInState(HRegionInfo, RegionState.State...) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
isRegionInState(String, RegionState.State...) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
isRegionInTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
isRegionInTransition(String) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
isRegionMarkedRecoveringInZK(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
check if /hbase/recovering-regions/<current region encoded name> exists.
isRegionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
isRegionOnline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
isRegionReplicaReplicationEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
 
isRegionReplicaStoreFileRefreshEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
 
isRegionReplicaWaitForPrimaryFlushEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
 
isRegionServerRemote - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
isRegionsInTransition() - Method in class org.apache.hadoop.hbase.master.RegionStates
 
isRegionStale(String, long) - Method in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
 
isReload() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
isRemote() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
The cause of a ForeignException can be an exception that was generated on a local in process thread, or a thread from a 'remote' separate process.
isReplay() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
isReplaying() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
 
isReplaying() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
isReplicasForSameRegion(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
 
isReplication(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
isReplicationForBulkLoadDataEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
isRescanNode(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
isRescanNode(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
isReservedFileInfoKey(byte[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Return true if the given file info key is reserved for internal use.
isResigned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isResigned() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isRestoreDone(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Returns the status of a restore operation.
isRestoreSnapshotDone(RpcController, MasterProtos.IsRestoreSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Returns the status of the requested snapshot restore/clone operation.
isRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
 
isRetryImmediatelySupported() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
 
isRetryImmediatelySupported() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
isReturnResults() - Method in class org.apache.hadoop.hbase.client.Append
 
isReturnResults() - Method in class org.apache.hadoop.hbase.client.Increment
 
isReturnResults() - Method in class org.apache.hadoop.hbase.client.Mutation
 
isReverse() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
isReverse() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
isReversed() - Method in class org.apache.hadoop.hbase.client.Scan
Get whether this scan is a reversed one.
isReversed() - Method in class org.apache.hadoop.hbase.filter.Filter
 
isReversed() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
isReversed() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
isReversed() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
isRoot() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
isRoot() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
methods
isRoot() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
isRootRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Check if the descriptor represents a -ROOT- region.
isRPCRunning() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
 
isRPCRunning() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
Indicates to the client whether this task is monitoring a currently active RPC call.
isRunnable() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
isRunning() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
isRunning() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
isRunning() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
 
isRunning() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
 
isRunning() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
isSameAddress(ServerName, ServerName) - Static method in class org.apache.hadoop.hbase.ServerName
 
isSameHdfs(Configuration, FileSystem, FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSHDFSUtils
 
isSameHostnameAndPort(ServerName, ServerName) - Static method in class org.apache.hadoop.hbase.ServerName
 
isScanMetricsEnabled() - Method in class org.apache.hadoop.hbase.client.Scan
 
isScheduled() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
isSearchRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
isSecure() - Method in class org.apache.hadoop.hbase.http.HttpConfig
 
isSecureZooKeeper(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Returns whether or not secure authentication is enabled (whether hbase.security.authentication is set to kerberos.
isSecurityAvailable(Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
 
isSecurityEnabled() - Static method in class org.apache.hadoop.hbase.security.User
Returns whether or not Kerberos authentication is configured for Hadoop.
isSecurityEnabled() - Static method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
Returns the result of UserGroupInformation.isSecurityEnabled().
isSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
isSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
isSeeked() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
isSequenceIdFile(Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
Is the given file a region open sequence id file.
isServerCrashProcessingEnabled() - Method in class org.apache.hadoop.hbase.master.HMaster
ServerCrashProcessingEnabled is set false before completing assignMeta to prevent processing of crashed servers.
isServerCrashProcessingEnabled() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
isServerDead(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
Check if a server is known to be dead.
isServerOnline(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
isServerReachable(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
Check if a region server is reachable and has the expected start code
isServerWithSameHostnamePortOnline(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
Check whether a server is online based on hostname and port
isSet(AlreadyExists._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BatchMutation._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ColumnDescriptor._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.append_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.append_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.atomicIncrement_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.atomicIncrement_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.checkAndPut_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.checkAndPut_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.compact_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.compact_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.createTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.createTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.deleteAll_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.deleteAll_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.deleteAllRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.deleteAllRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.deleteAllRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.deleteAllRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.deleteAllTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.deleteAllTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.deleteTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.deleteTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.disableTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.disableTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.enableTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.enableTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.get_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.get_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getColumnDescriptors_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getColumnDescriptors_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRegionInfo_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRegionInfo_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowOrBefore_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowOrBefore_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowsWithColumns_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowsWithColumns_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowsWithColumnsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowsWithColumnsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowWithColumns_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowWithColumns_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowWithColumnsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getRowWithColumnsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getTableNames_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getTableNames_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getTableRegions_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getTableRegions_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getVer_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getVer_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getVerTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.getVerTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.increment_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.increment_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.incrementRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.incrementRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.isTableEnabled_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.isTableEnabled_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.majorCompact_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.majorCompact_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.mutateRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.mutateRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.mutateRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.mutateRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.mutateRowsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.mutateRowsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.mutateRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.mutateRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerClose_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerClose_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerGet_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerGet_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerGetList_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerGetList_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerOpen_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerOpen_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerOpenTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerOpenTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerOpenWithPrefix_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerOpenWithPrefix_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerOpenWithScan_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerOpenWithScan_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerOpenWithStop_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerOpenWithStop_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerOpenWithStopTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Hbase.scannerOpenWithStopTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(IllegalArgument._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(IOError._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Mutation._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TAppend._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCell._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TColumn._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TRegionInfo._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TRowResult._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TScan._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TAppend._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TAuthorization._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCellVisibility._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TColumn._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TColumnIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TColumnValue._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TDelete._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGet._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.append_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.append_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.checkAndDelete_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.checkAndDelete_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.checkAndMutate_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.checkAndMutate_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.checkAndPut_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.checkAndPut_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.closeScanner_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.closeScanner_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.deleteMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.deleteMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.deleteSingle_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.deleteSingle_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.exists_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.exists_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.existsAll_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.existsAll_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.get_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.get_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.getAllRegionLocations_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.getAllRegionLocations_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.getMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.getMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.getRegionLocation_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.getRegionLocation_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.getScannerResults_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.getScannerResults_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.getScannerRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.getScannerRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.increment_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.increment_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.mutateRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.mutateRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.openScanner_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.openScanner_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.put_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.put_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.putMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THBaseService.putMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THRegionInfo._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(THRegionLocation._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TIllegalArgument._Fields) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TIOError._Fields) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TPut._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TResult._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TRowMutations._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TScan._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TServerName._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTimeRange._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSetAmmount() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
Returns true if field ammount is set (has been assigned a value) and false otherwise
isSetAmount() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
Returns true if field amount is set (has been assigned a value) and false otherwise
isSetAppend() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
Returns true if field append is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field attributes is set (has been assigned a value) and false otherwise
isSetAuthorizations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
Returns true if field authorizations is set (has been assigned a value) and false otherwise
isSetAuthorizations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field authorizations is set (has been assigned a value) and false otherwise
isSetBatchSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
Returns true if field batchSize is set (has been assigned a value) and false otherwise
isSetBatchSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field batchSize is set (has been assigned a value) and false otherwise
isSetBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
Returns true if field blockCacheEnabled is set (has been assigned a value) and false otherwise
isSetBloomFilterNbHashes() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
Returns true if field bloomFilterNbHashes is set (has been assigned a value) and false otherwise
isSetBloomFilterType() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
Returns true if field bloomFilterType is set (has been assigned a value) and false otherwise
isSetBloomFilterVectorSize() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
Returns true if field bloomFilterVectorSize is set (has been assigned a value) and false otherwise
isSetCacheBlocks() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
Returns true if field cacheBlocks is set (has been assigned a value) and false otherwise
isSetCacheBlocks() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field cacheBlocks is set (has been assigned a value) and false otherwise
isSetCaching() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
Returns true if field caching is set (has been assigned a value) and false otherwise
isSetCaching() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field caching is set (has been assigned a value) and false otherwise
isSetCell() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
Returns true if field cell is set (has been assigned a value) and false otherwise
isSetCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
Returns true if field cellVisibility is set (has been assigned a value) and false otherwise
isSetCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
Returns true if field cellVisibility is set (has been assigned a value) and false otherwise
isSetCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
Returns true if field cellVisibility is set (has been assigned a value) and false otherwise
isSetColFamTimeRangeMap() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field colFamTimeRangeMap is set (has been assigned a value) and false otherwise
isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
Returns true if field column is set (has been assigned a value) and false otherwise
isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
Returns true if field column is set (has been assigned a value) and false otherwise
isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
Returns true if field column is set (has been assigned a value) and false otherwise
isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
Returns true if field column is set (has been assigned a value) and false otherwise
isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
Returns true if field column is set (has been assigned a value) and false otherwise
isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
Returns true if field column is set (has been assigned a value) and false otherwise
isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
Returns true if field column is set (has been assigned a value) and false otherwise
isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
Returns true if field column is set (has been assigned a value) and false otherwise
isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
Returns true if field column is set (has been assigned a value) and false otherwise
isSetColumnFamilies() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
Returns true if field columnFamilies is set (has been assigned a value) and false otherwise
isSetColumnName() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
Returns true if field columnName is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumnValues() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
Returns true if field columnValues is set (has been assigned a value) and false otherwise
isSetColumnValues() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
Returns true if field columnValues is set (has been assigned a value) and false otherwise
isSetCompareOp() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
Returns true if field compareOp is set (has been assigned a value) and false otherwise
isSetCompression() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
Returns true if field compression is set (has been assigned a value) and false otherwise
isSetDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
isSetDeleteType() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
Returns true if field deleteType is set (has been assigned a value) and false otherwise
isSetDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
Returns true if field durability is set (has been assigned a value) and false otherwise
isSetDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
Returns true if field durability is set (has been assigned a value) and false otherwise
isSetDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
Returns true if field durability is set (has been assigned a value) and false otherwise
isSetDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
Returns true if field durability is set (has been assigned a value) and false otherwise
isSetEndKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
Returns true if field endKey is set (has been assigned a value) and false otherwise
isSetEndKey() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
Returns true if field endKey is set (has been assigned a value) and false otherwise
isSetExist() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
Returns true if field exist is set (has been assigned a value) and false otherwise
isSetExpression() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
Returns true if field expression is set (has been assigned a value) and false otherwise
isSetFamily() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
Returns true if field family is set (has been assigned a value) and false otherwise
isSetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
Returns true if field family is set (has been assigned a value) and false otherwise
isSetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
Returns true if field family is set (has been assigned a value) and false otherwise
isSetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
Returns true if field family is set (has been assigned a value) and false otherwise
isSetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
Returns true if field family is set (has been assigned a value) and false otherwise
isSetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
Returns true if field family is set (has been assigned a value) and false otherwise
isSetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
Returns true if field family is set (has been assigned a value) and false otherwise
isSetFilterString() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
Returns true if field filterString is set (has been assigned a value) and false otherwise
isSetFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
Returns true if field filterString is set (has been assigned a value) and false otherwise
isSetFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field filterString is set (has been assigned a value) and false otherwise
isSetHostName() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
Returns true if field hostName is set (has been assigned a value) and false otherwise
isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
Returns true if field ia is set (has been assigned a value) and false otherwise
isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
Returns true if field ia is set (has been assigned a value) and false otherwise
isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
Returns true if field ia is set (has been assigned a value) and false otherwise
isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
Returns true if field ia is set (has been assigned a value) and false otherwise
isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
Returns true if field ia is set (has been assigned a value) and false otherwise
isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
Returns true if field ia is set (has been assigned a value) and false otherwise
isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
Returns true if field ia is set (has been assigned a value) and false otherwise
isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
Returns true if field ia is set (has been assigned a value) and false otherwise
isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
Returns true if field ia is set (has been assigned a value) and false otherwise
isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
Returns true if field ia is set (has been assigned a value) and false otherwise
isSetIa() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
Returns true if field ia is set (has been assigned a value) and false otherwise
isSetIa() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
Returns true if field ia is set (has been assigned a value) and false otherwise
isSetId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
Returns true if field id is set (has been assigned a value) and false otherwise
isSetId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
Returns true if field id is set (has been assigned a value) and false otherwise
isSetId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
Returns true if field id is set (has been assigned a value) and false otherwise
isSetId() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
Returns true if field id is set (has been assigned a value) and false otherwise
isSetIncrement() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
Returns true if field increment is set (has been assigned a value) and false otherwise
isSetIncrements() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
Returns true if field increments is set (has been assigned a value) and false otherwise
isSetInMemory() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
Returns true if field inMemory is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
Returns true if field io is set (has been assigned a value) and false otherwise
isSetIsDelete() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
Returns true if field isDelete is set (has been assigned a value) and false otherwise
isSetLabels() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
Returns true if field labels is set (has been assigned a value) and false otherwise
isSetMaxStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
Returns true if field maxStamp is set (has been assigned a value) and false otherwise
isSetMaxVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
Returns true if field maxVersions is set (has been assigned a value) and false otherwise
isSetMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
Returns true if field maxVersions is set (has been assigned a value) and false otherwise
isSetMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field maxVersions is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMinStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
Returns true if field minStamp is set (has been assigned a value) and false otherwise
isSetMput() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
Returns true if field mput is set (has been assigned a value) and false otherwise
isSetMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
Returns true if field mutations is set (has been assigned a value) and false otherwise
isSetMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
Returns true if field mutations is set (has been assigned a value) and false otherwise
isSetMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
Returns true if field mutations is set (has been assigned a value) and false otherwise
isSetMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
Returns true if field mutations is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
Returns true if field name is set (has been assigned a value) and false otherwise
isSetNbRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
Returns true if field nbRows is set (has been assigned a value) and false otherwise
isSetNumRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
Returns true if field numRows is set (has been assigned a value) and false otherwise
isSetNumRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
Returns true if field numRows is set (has been assigned a value) and false otherwise
isSetNumVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
Returns true if field numVersions is set (has been assigned a value) and false otherwise
isSetNumVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
Returns true if field numVersions is set (has been assigned a value) and false otherwise
isSetOffline() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
Returns true if field offline is set (has been assigned a value) and false otherwise
isSetPort() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
Returns true if field port is set (has been assigned a value) and false otherwise
isSetPort() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
Returns true if field port is set (has been assigned a value) and false otherwise
isSetPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
isSetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
Returns true if field qualifier is set (has been assigned a value) and false otherwise
isSetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
Returns true if field qualifier is set (has been assigned a value) and false otherwise
isSetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
Returns true if field qualifier is set (has been assigned a value) and false otherwise
isSetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
Returns true if field qualifier is set (has been assigned a value) and false otherwise
isSetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
Returns true if field qualifier is set (has been assigned a value) and false otherwise
isSetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
Returns true if field qualifier is set (has been assigned a value) and false otherwise
isSetRegionId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
Returns true if field regionId is set (has been assigned a value) and false otherwise
isSetRegionInfo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
Returns true if field regionInfo is set (has been assigned a value) and false otherwise
isSetReload() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
Returns true if field reload is set (has been assigned a value) and false otherwise
isSetReplicaId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
Returns true if field replicaId is set (has been assigned a value) and false otherwise
isSetReversed() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
Returns true if field reversed is set (has been assigned a value) and false otherwise
isSetReversed() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field reversed is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRowBatches() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
Returns true if field rowBatches is set (has been assigned a value) and false otherwise
isSetRowBatches() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
Returns true if field rowBatches is set (has been assigned a value) and false otherwise
isSetRowMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
Returns true if field rowMutations is set (has been assigned a value) and false otherwise
isSetRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
Returns true if field rows is set (has been assigned a value) and false otherwise
isSetRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
Returns true if field rows is set (has been assigned a value) and false otherwise
isSetRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
Returns true if field rows is set (has been assigned a value) and false otherwise
isSetRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
Returns true if field rows is set (has been assigned a value) and false otherwise
isSetScan() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
Returns true if field scan is set (has been assigned a value) and false otherwise
isSetScannerId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
Returns true if field scannerId is set (has been assigned a value) and false otherwise
isSetScannerId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
Returns true if field scannerId is set (has been assigned a value) and false otherwise
isSetServerName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
Returns true if field serverName is set (has been assigned a value) and false otherwise
isSetServerName() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
Returns true if field serverName is set (has been assigned a value) and false otherwise
isSetSmall() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field small is set (has been assigned a value) and false otherwise
isSetSortColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
Returns true if field sortColumns is set (has been assigned a value) and false otherwise
isSetSortedColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
Returns true if field sortedColumns is set (has been assigned a value) and false otherwise
isSetSplit() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
Returns true if field split is set (has been assigned a value) and false otherwise
isSetStartAndPrefix() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
Returns true if field startAndPrefix is set (has been assigned a value) and false otherwise
isSetStartCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
Returns true if field startCode is set (has been assigned a value) and false otherwise
isSetStartKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
Returns true if field startKey is set (has been assigned a value) and false otherwise
isSetStartKey() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
Returns true if field startKey is set (has been assigned a value) and false otherwise
isSetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
Returns true if field startRow is set (has been assigned a value) and false otherwise
isSetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
Returns true if field startRow is set (has been assigned a value) and false otherwise
isSetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
Returns true if field startRow is set (has been assigned a value) and false otherwise
isSetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Returns true if field startRow is set (has been assigned a value) and false otherwise
isSetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
Returns true if field startRow is set (has been assigned a value) and false otherwise
isSetStartRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field startRow is set (has been assigned a value) and false otherwise
isSetStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
Returns true if field stopRow is set (has been assigned a value) and false otherwise
isSetStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Returns true if field stopRow is set (has been assigned a value) and false otherwise
isSetStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
Returns true if field stopRow is set (has been assigned a value) and false otherwise
isSetStopRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field stopRow is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
Returns true if field tableNameOrRegionName is set (has been assigned a value) and false otherwise
isSetTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
Returns true if field tableNameOrRegionName is set (has been assigned a value) and false otherwise
isSetTags() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
Returns true if field tags is set (has been assigned a value) and false otherwise
isSetTappend() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
Returns true if field tappend is set (has been assigned a value) and false otherwise
isSetTdelete() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
Returns true if field tdelete is set (has been assigned a value) and false otherwise
isSetTdelete() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
Returns true if field tdelete is set (has been assigned a value) and false otherwise
isSetTdeletes() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
Returns true if field tdeletes is set (has been assigned a value) and false otherwise
isSetTget() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
Returns true if field tget is set (has been assigned a value) and false otherwise
isSetTget() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
Returns true if field tget is set (has been assigned a value) and false otherwise
isSetTgets() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
Returns true if field tgets is set (has been assigned a value) and false otherwise
isSetTgets() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
Returns true if field tgets is set (has been assigned a value) and false otherwise
isSetTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
Returns true if field timeRange is set (has been assigned a value) and false otherwise
isSetTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
Returns true if field timeRange is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimeToLive() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
Returns true if field timeToLive is set (has been assigned a value) and false otherwise
isSetTincrement() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
Returns true if field tincrement is set (has been assigned a value) and false otherwise
isSetTput() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
Returns true if field tput is set (has been assigned a value) and false otherwise
isSetTput() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
Returns true if field tput is set (has been assigned a value) and false otherwise
isSetTputs() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
Returns true if field tputs is set (has been assigned a value) and false otherwise
isSetTrowMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
Returns true if field trowMutations is set (has been assigned a value) and false otherwise
isSetTscan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
Returns true if field tscan is set (has been assigned a value) and false otherwise
isSetTscan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
Returns true if field tscan is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValues() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
Returns true if field values is set (has been assigned a value) and false otherwise
isSetVersion() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
Returns true if field version is set (has been assigned a value) and false otherwise
isSetWriteToWAL() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
Returns true if field writeToWAL is set (has been assigned a value) and false otherwise
isShift() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
 
isShowConfInServlet() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
 
isShowQueueDump(Configuration) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
 
isShutdown() - Method in class org.apache.hadoop.hbase.ChoreService
 
isSingleNode() - Method in interface org.apache.hadoop.hbase.security.visibility.expression.ExpressionNode
 
isSingleNode() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
 
isSingleNode() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
 
isSingleRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
isSkipChecks() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
isSkippable() - Method in interface org.apache.hadoop.hbase.types.DataType
Indicates whether this instance is able to skip over it's encoded value.
isSkippable() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.PBType
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawByte
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawLong
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawShort
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.RawString
 
isSkippable - Variable in class org.apache.hadoop.hbase.types.Struct
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.Struct
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.Union2
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.Union3
 
isSkippable() - Method in class org.apache.hadoop.hbase.types.Union4
 
isSmall() - Method in class org.apache.hadoop.hbase.client.Scan
Get whether this scan is a small scan
isSmall() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
isSnapshotCorrupted() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Deprecated.
 
isSnapshotDone(RpcController, MasterProtos.IsSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Checks if the specified snapshot is done.
isSnapshotDone(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Check if the specified snapshot is done
isSnapshotFinished(HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
isSnapshotFinished(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Check the current state of the passed snapshot.
isSnapshotOwner(HBaseProtos.SnapshotDescription, User) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Check if the user is this table snapshot's owner
isSortColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
isSorted(Collection<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
isSpecialException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
 
isSplit() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isSplit() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isSplit() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
isSplitOrMergeEnabled(Admin.MasterSwitchType) - Method in interface org.apache.hadoop.hbase.client.Admin
Query the current state of the switch
isSplitOrMergeEnabled(Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isSplitOrMergeEnabled(Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.HMaster
Queries the state of the SplitOrMergeTracker.
isSplitOrMergeEnabled(RpcController, MasterProtos.IsSplitOrMergeEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isSplitOrMergeEnabled(Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.zookeeper.SplitOrMergeTracker
 
isSplitParent() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isSplittable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isSplitting() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
 
isSplitting() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
isSplitting() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isSplittingNew() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isStale() - Method in class org.apache.hadoop.hbase.client.Result
Whether or not the results are coming from possibly stale data.
isStarted() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
isStarted() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
 
isStarted(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Return true if the procedure is started.
isStartingWithPath(Path, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Compare of path component.
isStateEnabled(byte[]) - Static method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Parse the raw data from ZK to get a peer's state
isStop() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
 
isStop() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
 
isStopped() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
isStopped() - Method in class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
 
isStopped() - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
 
isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
 
isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
 
isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
isStopped() - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
 
isStopped() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
 
isStopped() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
isStopped() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionsCleaner
 
isStopped() - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
 
isStopped() - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
isStopped() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
 
isStopped() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
 
isStopped() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
isStopped() - Method in interface org.apache.hadoop.hbase.Stoppable
 
isStopping() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
isStopping() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
isSubDirectoryOf(Path, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Determines if the given workingDir is a subdirectory of the given "root directory"
isSuccess() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
isSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
isSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
isSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
isSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
isSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
isSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
issueDate - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
isSuperUser(User) - Static method in class org.apache.hadoop.hbase.security.Superusers
 
isSuperUser(String) - Static method in class org.apache.hadoop.hbase.security.Superusers
Deprecated.
this method is for backward compatibility, use Superusers.isSuperUser(User) instead
isSuperUserId(String[], Id) - Static method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
isSystemTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isSystemTable() - Method in class org.apache.hadoop.hbase.TableName
 
isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
 
isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
Use this api to check if the table has been created with the specified number of splitkeys which was used while creating the given table.
isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Use this api to check if the table has been created with the specified number of splitkeys which was used while creating the given table.
isTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Use this api to check if the table has been created with the specified number of splitkeys which was used while creating the given table.
isTableAvailable(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(String, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
 
isTableAvailable(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
isTableAvailable(byte[], byte[][]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
isTableAvailable(String) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
isTableAvailableAndInitialized(boolean) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
This method checks if the namespace table is assigned and then tries to create its HTable.
isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
 
isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableDisabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableDisabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
 
isTableDisabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
 
isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
A table that isTableEnabled == false and isTableDisabled == false is possible.
isTableEnabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
isTableEnabled(String) - Static method in class org.apache.hadoop.hbase.client.HTable
isTableEnabled(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
isTableEnabled(TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
isTableEnabled(Configuration, String) - Static method in class org.apache.hadoop.hbase.client.HTable
isTableEnabled(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
isTableEnabled(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
isTableEnabled(ByteBuffer, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
isTableEnabled(ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
isTableEnabled(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
isTableEnabled(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
 
isTableEnabled(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
isTableInfoExists(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Checks if a current table info file exists for the given table
isTablePresent(TableName) - Method in interface org.apache.hadoop.hbase.TableStateManager
Checks if table is present.
isTablePresent(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
check if table is present.
isTableRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isTableState(TableName, ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
 
isTableState(TableName, boolean, ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
 
isTableState(TableName, ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
Checks if table is marked in specified state in ZK (using cache only).
isTableState(TableName, boolean, ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
Checks if table is marked in specified state in ZK.
isTagsPresent() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
 
isTakingAnySnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
The snapshot operation processing as following:
1.
isTaskPath(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
isTerminated() - Method in class org.apache.hadoop.hbase.ChoreService
 
isTEST_FORCE_REFRESH() - Static method in class org.apache.hadoop.hbase.quotas.QuotaCache
 
isText(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return true when the next encoded value in src uses Text encoding, false otherwise.
isThisOurRegionServer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Checks if the provided znode is the same as this region server's
isThisOurRegionServer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
isThisOurZnode(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Checks if the provided znode is the same as this region server's
isThisOurZnode(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
isTop() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
 
isTopFileRegion(Reference.Range) - Static method in class org.apache.hadoop.hbase.io.Reference
 
isTopReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isTracking(long, long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
isTrackingMetrics() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
 
isUnassignable() - Method in class org.apache.hadoop.hbase.master.RegionState
Check if a region state is one of offline states that can't transition to pending_close/closing (unassign/offline)
isUnassignable(RegionState.State) - Static method in class org.apache.hadoop.hbase.master.RegionState
Check if a region state is one of offline states that can't transition to pending_close/closing (unassign/offline)
isUnassigned() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
isUnassigned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isUnassigned() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isUnderline() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
isUnderline() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
isUninstantiated() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
isUnix() - Static method in class org.apache.hadoop.hbase.util.JVM
Check if the OS is unix.
isUnpacked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Return true when this block's buffer has been unpacked, false otherwise.
isUpdated() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
isUpdated() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
isUsecache() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
 
isUseHBaseChecksum() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
isUserRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
isUserScan() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
isUserScan() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.LegacyScanQueryMatcher
Deprecated.
 
isUserScan() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
isUserScan() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
isUsingL0Flush() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
 
isValid() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
isValid(FileStatus) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Return if the specified file is a valid store file or not.
isValidLabel(byte[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
 
isValidName(String) - Method in class org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
 
isValidName(String) - Method in class org.apache.hadoop.hbase.util.FSUtils.UserTableDirFilter
 
isValidProtocol(String) - Static method in class org.apache.hadoop.hbase.http.log.LogLevel
 
isValidState(ScannerContext.NextState) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
 
isVisibilityTagsPresent(Cell) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
 
isWaiting() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
isWithinDefaultWorkingDir(Path, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Determines if the given workingDir is a subdirectory of the default working snapshot directory
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.PlainTextMessageBodyProducer
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.ProtobufMessageBodyProducer
 
isWriteSuccess() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
isWriteToWAL() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
isYieldAfterExecutionStep(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
By default, the executor will try ro run procedures start to finish.
isYieldAfterExecutionStep(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
 
isYieldBeforeExecuteFromState(MasterProcedureEnv, MasterProcedureProtos.ServerCrashState) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
For this procedure, yield at end of each successful flow step so that all crashed servers can make progress rather than do the default which has each procedure running to completion before we move to the next.
isYieldBeforeExecuteFromState(TEnvironment, TState) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
By default, the executor will try ro run all the steps of the procedure start to finish.
IterableUtils - Class in org.apache.hadoop.hbase.util
Utility methods for Iterable including null-safe handlers.
IterableUtils() - Constructor for class org.apache.hadoop.hbase.util.IterableUtils
 
iterateOnSplits(byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Iterate over keys within the passed range, splitting at an [a,b) boundary.
iterateOnSplits(byte[], byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Iterate over keys within the passed range.
iterator() - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
 
iterator() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
iterator() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
 
iterator() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
iterator() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
iterator() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
iterator() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
iterator() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
iterator() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
 
iterator() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
iterator() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
 
iterator() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
iterator(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
Retrieve an Iterator over the values encoded in src.
iterator() - Method in class org.apache.hadoop.hbase.util.BoundedArrayQueue
Not implemented and will throw UnsupportedOperationException
iterator() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
iterator() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
 
iterator() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
iterator() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
iterator() - Method in class org.apache.hadoop.hbase.util.SortedList
 
IV_LENGTH - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
 

J

JacksonProvider - Class in org.apache.hadoop.hbase.rest.provider
 
JacksonProvider() - Constructor for class org.apache.hadoop.hbase.rest.provider.JacksonProvider
 
jarDir(File, String, ZipOutputStream) - Static method in class org.apache.hadoop.hbase.mapreduce.JarFinder
 
JarFinder - Class in org.apache.hadoop.hbase.mapreduce
Finds the Jar for a class.
JarFinder() - Constructor for class org.apache.hadoop.hbase.mapreduce.JarFinder
 
JAXBContextResolver - Class in org.apache.hadoop.hbase.rest.provider
Plumbing for hooking up Jersey's JSON entity body encoding and decoding support to JAXB.
JAXBContextResolver() - Constructor for class org.apache.hadoop.hbase.rest.provider.JAXBContextResolver
 
JENKINS_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
Constant to denote JenkinsHash.
JenkinsHash - Class in org.apache.hadoop.hbase.util
Produces 32-bit hash for hash table lookup.
JenkinsHash() - Constructor for class org.apache.hadoop.hbase.util.JenkinsHash
 
JERSEYVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
JitterScheduledThreadPoolExecutorImpl - Class in org.apache.hadoop.hbase
ScheduledThreadPoolExecutor that will add some jitter to the RunnableScheduledFuture.getDelay.
JitterScheduledThreadPoolExecutorImpl(int, ThreadFactory, double) - Constructor for class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl
Main constructor.
JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture<V> - Class in org.apache.hadoop.hbase
Class that basically just defers to the wrapped future.
JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
JmxCacheBuster - Class in org.apache.hadoop.metrics2.impl
JMX caches the beans that have been exported; even after the values are removed from hadoop's metrics system the keys and old values will still remain.
JMXJsonServlet - Class in org.apache.hadoop.hbase.http.jmx
Provides Read only web access to JMX.
JMXJsonServlet() - Constructor for class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
 
JMXListener - Class in org.apache.hadoop.hbase
Pluggable JMX Agent for HBase(to fix the 2 random TCP ports issue of the out-of-the-box JMX Agent): 1)connector port can share with the registry port if SSL is OFF 2)support password authentication 3)support subset of SSL (with default configuration)
JMXListener() - Constructor for class org.apache.hadoop.hbase.JMXListener
 
JOB_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
JobUtil - Class in org.apache.hadoop.hbase.mapreduce
Utility methods to interact with a job.
JobUtil() - Constructor for class org.apache.hadoop.hbase.mapreduce.JobUtil
 
join() - Method in class org.apache.hadoop.hbase.http.HttpServer
 
join() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
Wait for the server to be stopped.
join() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
 
join() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Wait for Mini HBase Cluster to shut down.
join() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
join() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
Join with the replication threads
join() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Terminate the replication on this region server
join() - Method in class org.apache.hadoop.hbase.util.HasThread
 
join(long, int) - Method in class org.apache.hadoop.hbase.util.HasThread
 
join(long) - Method in class org.apache.hadoop.hbase.util.HasThread
 
joinZNode(String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Join the prefix znode name with the suffix znode name to generate a proper full znode name.
JSONBean - Class in org.apache.hadoop.hbase.util
Utility for doing JSON and MBeans.
JSONBean() - Constructor for class org.apache.hadoop.hbase.util.JSONBean
 
JSONBean.Writer - Interface in org.apache.hadoop.hbase.util
Use dumping out mbeans as JSON.
jsonBeanWriter - Variable in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
 
JsonMapper - Class in org.apache.hadoop.hbase.util
Utility class for converting objects to JSON
JVM - Class in org.apache.hadoop.hbase.util
This class is a wrapper for the implementation of com.sun.management.UnixOperatingSystemMXBean It will decide to use the sun api or its own implementation depending on the runtime (vendor) used.
JVM() - Constructor for class org.apache.hadoop.hbase.util.JVM
Constructor.
JVMClusterUtil - Class in org.apache.hadoop.hbase.util
Utility used running a cluster all in the one JVM.
JVMClusterUtil() - Constructor for class org.apache.hadoop.hbase.util.JVMClusterUtil
 
JVMClusterUtil.MasterThread - Class in org.apache.hadoop.hbase.util
Datastructure to hold Master Thread and Master instance
JVMClusterUtil.MasterThread(HMaster, int) - Constructor for class org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread
 
JVMClusterUtil.RegionServerThread - Class in org.apache.hadoop.hbase.util
Datastructure to hold RegionServer Thread and RegionServer instance
JVMClusterUtil.RegionServerThread(HRegionServer, int) - Constructor for class org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
 
JvmPauseMonitor - Class in org.apache.hadoop.hbase.util
Class which sets up a simple thread which runs in a loop sleeping for a short interval of time.
JvmPauseMonitor(Configuration) - Constructor for class org.apache.hadoop.hbase.util.JvmPauseMonitor
 
JvmPauseMonitor(Configuration, JvmPauseMonitorSource) - Constructor for class org.apache.hadoop.hbase.util.JvmPauseMonitor
 
JvmPauseMonitorSource - Interface in org.apache.hadoop.hbase.metrics
Interface for sources that will export JvmPauseMonitor metrics
JvmVersion - Class in org.apache.hadoop.hbase.util
Certain JVM versions are known to be unstable with HBase.
JvmVersion() - Constructor for class org.apache.hadoop.hbase.util.JvmVersion
 
JVMVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 

K

K - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'K'
KEEP_DELETED_CELLS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
KEEP_REGION_LOADS - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
KEEP_SEQID_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for # days to keep MVCC values during a major compaction
KeepDeletedCells - Enum in org.apache.hadoop.hbase
Ways to keep cells marked for delete around.
keepDeletedCells - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
whether to return deleted rows
keeperException(KeeperException) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Handles KeeperExceptions in client calls.
keepHFiles(String) - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
Determine if the given table should or should not allow its hfiles to be deleted
keepRegionEvent(WAL.Entry) - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
Some WALEdit's contain only KV's for account on what happened to a region.
keepSeqIdPeriod - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
specify how many days to keep MVCC values during major compaction
key - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The key
KEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
KEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
KEY_FOR_HOSTNAME_SEEN_BY_MASTER - Static variable in class org.apache.hadoop.hbase.HConstants
 
KEY_INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
 
KEY_LENGTH - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
KEY_LENGTH_BITS - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
KEY_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
Size of the key length field in bytes
KEY_MAX_REGIONS - Static variable in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
KEY_MAX_TABLES - Static variable in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.trace.HBaseHTraceConfiguration
 
KEY_RETRIES_ON_META - Static variable in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
Configuration key to set how many retries to cycle before we give up on meta.
KEY_SHORT_WAIT_ON_META - Static variable in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
Configuration key to set how long to wait in ms doing a quick check on meta state.
KEY_VALUE_LEN_SIZE - Static variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
The size of a (key length, value length) tuple that prefixes each entry in a data block.
KEY_VALUE_LEN_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
The size of a (key length, value length) tuple that prefixes each entry in a data block.
KEY_VALUE_VER_WITH_MEMSTORE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Version for KeyValue which includes memstore timestamp
KEY_VALUE_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
KeyValue version in FileInfo
KEY_WAIT_ON_RIT - Static variable in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
Configuration key to set how long to wait in ms on regions in transition.
KEY_WORD_TRUNCATED - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
keyBuffer - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
keyCount - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Keys currently in the bloom
keyId - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
keyLength - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
keyLength(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Returns number of bytes this cell's key part would have been used if serialized as in KeyValue.
KeyLocker<K> - Class in org.apache.hadoop.hbase.util
A utility class to manage a set of locks.
KeyLocker() - Constructor for class org.apache.hadoop.hbase.util.KeyLocker
 
keyOnly(byte[]) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
 
KeyOnlyFilter - Class in org.apache.hadoop.hbase.filter
A filter that will only return the key component of each KV (the value will be rewritten as empty).
KeyOnlyFilter() - Constructor for class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
KeyOnlyFilter(boolean) - Constructor for class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
keyPassword(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
KeyPrefixRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
A custom RegionSplitPolicy implementing a SplitPolicy that groups rows by a prefix of the row-key This ensures that a region is not split "inside" a prefix of a row key.
KeyPrefixRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
 
KeyPress - Class in org.apache.hadoop.hbase.hbtop.terminal
Represents the user pressing a key on the keyboard.
KeyPress(KeyPress.Type, Character, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
 
KeyPress.Type - Enum in org.apache.hadoop.hbase.hbtop.terminal
 
KeyPressGenerator - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
This generates KeyPress objects from the given input stream and offers them to the given queue.
KeyPressGenerator(InputStream, Queue<KeyPress>) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
 
KeyProvider - Interface in org.apache.hadoop.hbase.io.crypto
KeyProvider is a interface to abstract the different methods of retrieving key material from key storage such as Java key store.
KeyRange - Interface in org.apache.hadoop.hbase.util
A key range use in split coverage.
keySet() - Method in class org.apache.hadoop.hbase.hbtop.Record
 
keySet() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
keySet() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
keySet() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
keySet() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
keyStore(String, String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
KeyStoreKeyProvider - Class in org.apache.hadoop.hbase.io.crypto
A basic KeyProvider that can resolve keys from a protected KeyStore file on the local filesystem.
KeyStoreKeyProvider() - Constructor for class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
keyToString(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
 
keyToString(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
Use for logging.
KeyValue - Class in org.apache.hadoop.hbase
An HBase Key/Value.
KeyValue() - Constructor for class org.apache.hadoop.hbase.KeyValue
Writable Constructor -- DO NOT USE
KeyValue(byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue from the start of the specified byte array.
KeyValue(byte[], int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue from the specified byte array and offset.
KeyValue(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue from the specified byte array, starting at offset, and for length length.
KeyValue(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue from the specified byte array, starting at offset, and for length length.
KeyValue(byte[], long) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with null value.
KeyValue(byte[], long, KeyValue.Type) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with null value.
KeyValue(byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with null value.
KeyValue(byte[], byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure as a put filled with specified values and LATEST_TIMESTAMP.
KeyValue(byte[], byte[], byte[], long, KeyValue.Type) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, byte[], Tag[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, byte[], List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, KeyValue.Type, byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, KeyValue.Type, byte[], List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, KeyValue.Type, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], int, int, long, KeyValue.Type, byte[], int, int, List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], int, int, long, KeyValue.Type, byte[], int, int, byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
 
KeyValue(byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], int, byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int, Tag[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int, List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int, byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
 
KeyValue(int, int, int, long, KeyValue.Type, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs an empty KeyValue structure, with specified sizes.
KeyValue(int, int, int, long, KeyValue.Type, int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs an empty KeyValue structure, with specified sizes.
KeyValue(byte[], int, int, byte[], int, int, ByteBuffer, long, KeyValue.Type, ByteBuffer, List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
 
KeyValue(Cell) - Constructor for class org.apache.hadoop.hbase.KeyValue
 
KeyValue.KeyOnlyKeyValue - Class in org.apache.hadoop.hbase
A simple form of KeyValue that creates a keyvalue with only the key part of the byte[] Mainly used in places where we need to compare two cells.
KeyValue.KeyOnlyKeyValue() - Constructor for class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
KeyValue.KeyOnlyKeyValue(byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
KeyValue.KeyOnlyKeyValue(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
KeyValue.KVComparator - Class in org.apache.hadoop.hbase
Compare KeyValues.
KeyValue.KVComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.KVComparator
 
KeyValue.MetaComparator - Class in org.apache.hadoop.hbase
A KeyValue.KVComparator for hbase:meta catalog table KeyValues.
KeyValue.MetaComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.MetaComparator
 
KeyValue.RawBytesComparator - Class in org.apache.hadoop.hbase
This is a TEST only Comparator used in TestSeekTo and TestReseekTo.
KeyValue.RawBytesComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.RawBytesComparator
 
KeyValue.RowOnlyComparator - Class in org.apache.hadoop.hbase
Comparator that compares row component only of a KeyValue.
KeyValue.RowOnlyComparator(KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.KeyValue.RowOnlyComparator
 
KeyValue.SamePrefixComparator<T> - Interface in org.apache.hadoop.hbase
Avoids redundant comparisons for better performance.
KeyValue.Type - Enum in org.apache.hadoop.hbase
Key type.
KEYVALUE_INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
 
KEYVALUE_WITH_TAGS_INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
 
KeyValueCodec - Class in org.apache.hadoop.hbase.codec
Codec that does KeyValue version 1 serialization.
KeyValueCodec() - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodec
 
KeyValueCodec.KeyValueDecoder - Class in org.apache.hadoop.hbase.codec
 
KeyValueCodec.KeyValueDecoder(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueDecoder
 
KeyValueCodec.KeyValueEncoder - Class in org.apache.hadoop.hbase.codec
 
KeyValueCodec.KeyValueEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueEncoder
 
KeyValueCodecWithTags - Class in org.apache.hadoop.hbase.codec
Codec that does KeyValue version 1 serialization with serializing tags also.
KeyValueCodecWithTags() - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
 
KeyValueCodecWithTags.KeyValueDecoder - Class in org.apache.hadoop.hbase.codec
 
KeyValueCodecWithTags.KeyValueDecoder(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueDecoder
 
KeyValueCodecWithTags.KeyValueEncoder - Class in org.apache.hadoop.hbase.codec
 
KeyValueCodecWithTags.KeyValueEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueEncoder
 
KeyValueHeap - Class in org.apache.hadoop.hbase.regionserver
Implements a heap merge across any number of KeyValueScanners.
KeyValueHeap(List<? extends KeyValueScanner>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Constructor.
KeyValueHeap.KVScannerComparator - Class in org.apache.hadoop.hbase.regionserver
 
KeyValueHeap.KVScannerComparator(KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
Constructor
KeyValueScanner - Interface in org.apache.hadoop.hbase.regionserver
Scanner that returns the next KeyValue.
KeyValueSerialization - Class in org.apache.hadoop.hbase.mapreduce
 
KeyValueSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
 
KeyValueSerialization.KeyValueDeserializer - Class in org.apache.hadoop.hbase.mapreduce
 
KeyValueSerialization.KeyValueDeserializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueDeserializer
 
KeyValueSerialization.KeyValueSerializer - Class in org.apache.hadoop.hbase.mapreduce
 
KeyValueSerialization.KeyValueSerializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
 
KeyValueSortReducer - Class in org.apache.hadoop.hbase.mapreduce
Emits sorted KeyValues.
KeyValueSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.KeyValueSortReducer
 
KeyValueTestUtil - Class in org.apache.hadoop.hbase
 
KeyValueTestUtil() - Constructor for class org.apache.hadoop.hbase.KeyValueTestUtil
 
KeyValueUtil - Class in org.apache.hadoop.hbase
static convenience methods for dealing with KeyValues and collections of KeyValues
KeyValueUtil() - Constructor for class org.apache.hadoop.hbase.KeyValueUtil
 
kill() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
killBeforeStoreUpdate - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.Testing
 
killCurrentActiveZooKeeperServer() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
killOneBackupZooKeeperServer() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
Kill one back up ZK servers
kvComparator - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
 
kvCreator - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
KVP_DELIMITER - Static variable in class org.apache.hadoop.hbase.util.ConfigurationUtil
 

L

L - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'L'
L1_CACHE_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L1_CACHE_HIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L1_CACHE_HIT_RATIO - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L1_CACHE_HIT_RATIO_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L1_CACHE_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L1_CACHE_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L1_CACHE_MISS_RATIO - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L1_CACHE_MISS_RATIO_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L2_CACHE_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L2_CACHE_HIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L2_CACHE_HIT_RATIO - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L2_CACHE_HIT_RATIO_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L2_CACHE_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L2_CACHE_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L2_CACHE_MISS_RATIO - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
L2_CACHE_MISS_RATIO_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
l2Cache - Variable in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
LABEL_QUALIFIER - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Qualifier for the internal storage table for visibility labels
LabelAlreadyExistsException - Exception in org.apache.hadoop.hbase.security.visibility
 
LabelAlreadyExistsException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.LabelAlreadyExistsException
 
labels - Variable in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
LABELS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
LABELS_TABLE_FAMILY - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Family for the internal storage table for visibility labels
LABELS_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Internal storage table for visibility labels
languageVersion() - Static method in class org.apache.hadoop.hbase.classification.tools.ExcludePrivateAnnotationsStandardDoclet
 
languageVersion() - Static method in class org.apache.hadoop.hbase.classification.tools.IncludePublicAnnotationsStandardDoclet
 
LARGE_COMPACTION_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
LARGE_COMPACTION_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
LARGE_COMPACTION_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
LARGE_COMPACTION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
LARGE_HFILE_DELETE_THREAD_NUMBER - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
LARGE_HFILE_QUEUE_INIT_SIZE - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
last() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
last() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
LAST_MAJOR_COMPACTION_AGE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
LAST_MAJOR_COMPACTION_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
LAST_ROW - Static variable in class org.apache.hadoop.hbase.HConstants
Used by scanners and others when they're trying to detect the end of a table
last_update - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
last_version - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
lastCell - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
The Cell previously appended.
lastDataBlockOffset - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
The offset of the last data block or 0 if the file is empty.
lastEntry() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
lastFlushedSequenceIds - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
 
lastHost - Variable in class org.apache.hadoop.hbase.rest.client.Cluster
 
lastIndexOf(Object) - Method in class org.apache.hadoop.hbase.util.SortedList
 
lastKey - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Last key in the file.
lastKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
lastKey() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
lastNext - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
lastNodeId - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
lastReplayedCompactionSeqId - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
lastReplayedOpenRegionSeqId - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
The sequence id of the last replayed open region event from the primary region.
lastResult - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
lastRow() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
 
lastRow() - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
In HBase, the last row is represented by an empty byte array.
lastRow() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
lastRowInCurrentWriter - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
 
LastSequenceId - Interface in org.apache.hadoop.hbase.regionserver
Last flushed sequence Ids for the regions and their stores on region server
lastTop - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
LATEST_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.HConstants
Timestamp to use when we want to refer to the latest cell.
LATEST_TIMESTAMP_BYTES - Static variable in class org.apache.hadoop.hbase.HConstants
LATEST_TIMESTAMP in bytes form
latestVersionOnly - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
lazySeekEnabledGlobally - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
Used during unit testing to ensure that lazy seek does save seek ops
LeafExpressionNode - Class in org.apache.hadoop.hbase.security.visibility.expression
 
LeafExpressionNode(String) - Constructor for class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
 
leafWriters - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
leaseCheckFrequency - Variable in class org.apache.hadoop.hbase.regionserver.Leases
 
LeaseException - Exception in org.apache.hadoop.hbase.regionserver
Reports a problem with a lease
LeaseException() - Constructor for exception org.apache.hadoop.hbase.regionserver.LeaseException
default constructor
LeaseException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.LeaseException
 
leaseExpired() - Method in interface org.apache.hadoop.hbase.regionserver.LeaseListener
When a lease expires, this method is called.
LeaseListener - Interface in org.apache.hadoop.hbase.regionserver
LeaseListener is an interface meant to be implemented by users of the Leases class.
LeaseNotRecoveredException - Exception in org.apache.hadoop.hbase.util
Thrown when the lease was expected to be recovered, but the file can't be opened.
LeaseNotRecoveredException() - Constructor for exception org.apache.hadoop.hbase.util.LeaseNotRecoveredException
 
LeaseNotRecoveredException(String) - Constructor for exception org.apache.hadoop.hbase.util.LeaseNotRecoveredException
 
LeaseNotRecoveredException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.util.LeaseNotRecoveredException
 
LeaseNotRecoveredException(Throwable) - Constructor for exception org.apache.hadoop.hbase.util.LeaseNotRecoveredException
 
leases - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
Leases - Class in org.apache.hadoop.hbase.regionserver
Leases There are several server classes in HBase that need to track external clients that occasionally send heartbeats.
Leases(int) - Constructor for class org.apache.hadoop.hbase.regionserver.Leases
Creates a lease monitor
Leases.LeaseStillHeldException - Exception in org.apache.hadoop.hbase.regionserver
Thrown if we are asked to create a lease but lease on passed name already exists.
Leases.LeaseStillHeldException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.Leases.LeaseStillHeldException
 
leaves - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
LegacyScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
Deprecated.
legacyWarning(Class<? extends Coprocessor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
limits the amount of logging to once per coprocessor class.
len(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Returns length of the byte array, returning 0 if the array is null.
LENGTH - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
length() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
length() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
length - Variable in class org.apache.hadoop.hbase.KeyValue
 
length(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Returns number of bytes this cell would have been used if serialized as in KeyValue
length() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
length - Variable in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
length - Variable in class org.apache.hadoop.hbase.util.AbstractByteRange
The number of bytes in the range.
length(byte[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
 
length(long[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
 
length(Object[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
 
length(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Return the number of encoded entries remaining in buff.
lengthOfPBMagic() - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
lengthWithMvccVersion(KeyValue, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
less(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
less(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
LESS_THAN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
LESS_THAN Array
LESS_THAN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
LESS_THAN_OR_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
LESS_THAN_OR_EQUAL_TO Array
LESS_THAN_OR_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
lessOrEqual(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
lessOrEqual(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
LIB_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
The directory from which co-processor/custom filter jars can be loaded dynamically by the region servers.
limit - Variable in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
 
limit - Variable in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
LimitInputStream - Class in org.apache.hadoop.hbase.io
Copied from guava source code v15 (LimitedInputStream) Guava deprecated LimitInputStream in v14 and removed it in v15.
LimitInputStream(InputStream, long) - Constructor for class org.apache.hadoop.hbase.io.LimitInputStream
 
limitNumMapTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Ensures that the given number of map tasks for the given job configuration does not exceed the number of regions for the given table.
limitNumReduceTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Ensures that the given number of reduce tasks for the given job configuration does not exceed the number of regions for the given table.
limitNumReduceTasks(String, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Ensures that the given number of reduce tasks for the given job configuration does not exceed the number of regions for the given table.
limitReached() - Method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
 
LINK_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.io.HFileLink
A non-capture group, for HFileLink, so that this can be embedded.
list() - Method in class org.apache.hadoop.hbase.client.Result
Deprecated.
as of 0.96, use Result.listCells()
list() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
list() - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
 
listAllRegions(Configuration, Connection, boolean) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Lists all of the regions currently in META.
listCells() - Method in class org.apache.hadoop.hbase.client.Result
Create a sorted list of the Cell's in this result.
listChildrenAndWatchForNewChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Lists the children znodes of the specified znode.
listChildrenAndWatchThem(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
List all the children of the specified znode, setting a watch for children changes and also setting a watch on every individual child in order to get the NodeCreated and NodeDeleted events.
listChildrenNoWatch(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Lists the children of the specified znode without setting any watches.
listDeadServers() - Method in interface org.apache.hadoop.hbase.client.Admin
List dead region servers.
listDeadServers() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listener(BufferedMutator.ExceptionListener) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Override the default error handler.
listeners - Variable in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
 
listIterator() - Method in class org.apache.hadoop.hbase.util.SortedList
 
listIterator(int) - Method in class org.apache.hadoop.hbase.util.SortedList
 
listLabels(String) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
listLabels(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
listLabels(Connection, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
Retrieve the list of visibility labels defined in the system.
listLabels(RpcController, VisibilityLabelsProtos.ListLabelsRequest, RpcCallback<VisibilityLabelsProtos.ListLabelsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
listLabels(String) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
Retrieve the list of visibility labels defined in the system.
listLocatedStatus(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Calls fs.listFiles() to get FileStatus and BlockLocations together for reducing rpc call
listNamespaceDescriptors() - Method in interface org.apache.hadoop.hbase.client.Admin
List available namespace descriptors
listNamespaceDescriptors() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List available namespace descriptors
listNamespaceDescriptors() - Method in class org.apache.hadoop.hbase.master.HMaster
 
listNamespaceDescriptors(RpcController, MasterProtos.ListNamespaceDescriptorsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
listNamespaceDescriptors() - Method in interface org.apache.hadoop.hbase.master.MasterServices
List available namespace descriptors
listPeerConfigs() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
listPeers() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
listProcedures() - Method in interface org.apache.hadoop.hbase.client.Admin
List procedures
listProcedures() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List procedures
listProcedures() - Method in class org.apache.hadoop.hbase.master.HMaster
 
listProcedures(RpcController, MasterProtos.ListProceduresRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
listProcedures() - Method in interface org.apache.hadoop.hbase.master.MasterServices
List procedures
listProcedures() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
List procedures.
listReplicated() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Find all column families that are replicated from this cluster
listRSGroupInfos(RpcController, RSGroupAdminProtos.ListRSGroupInfosRequest, RpcCallback<RSGroupAdminProtos.ListRSGroupInfosResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
listRSGroups() - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Lists current set of RegionServer groups.
listRSGroups() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
listRSGroups() - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
List the existing RSGroupInfos.
listRSGroups() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
listSnapshots() - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
listSnapshots(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
listSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
listSnapshots() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List completed snapshots.
listSnapshots(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List all the completed snapshots matching the given regular expression.
listSnapshots(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List all the completed snapshots matching the given pattern.
listStatus(FileSystem, Path, PathFilter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Calls fs.listStatus() and treats FileNotFoundException as non-fatal This accommodates differences between hadoop versions, where hadoop 1 does not throw a FileNotFoundException, and return an empty FileStatus[] while Hadoop 2 will throw FileNotFoundException.
listStatus(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Calls fs.listStatus() and treats FileNotFoundException as non-fatal This would accommodates differences between hadoop versions
listStatusWithStatusFilter(FileSystem, Path, FileStatusFilter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Calls fs.listStatus() and treats FileNotFoundException as non-fatal This accommodates differences between hadoop versions, where hadoop 1 does not throw a FileNotFoundException, and return an empty FileStatus[] while Hadoop 2 will throw FileNotFoundException.
listTableDescriptors(String, String, List<TableName>, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
Returns the list of table descriptors that match the specified request
listTableDescriptorsByNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Get list of table descriptors by namespace
listTableDescriptorsByNamespace(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get list of table descriptors by namespace
listTableDescriptorsByNamespace(String) - Method in class org.apache.hadoop.hbase.master.HMaster
 
listTableDescriptorsByNamespace(RpcController, MasterProtos.ListTableDescriptorsByNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
listTableDescriptorsByNamespace(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Get list of table descriptors by namespace
listTableNames() - Method in interface org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames(String) - Method in interface org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames(String, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
List all of the names of userspace tables.
listTableNames() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames(Pattern, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames(String, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTableNames() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Use Admin.listTables() instead.
listTableNames(String, String, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
Returns the list of table names that match the specified request
listTableNamesByNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Get list of table names by namespace
listTableNamesByNamespace(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get list of table names by namespace
listTableNamesByNamespace(String) - Method in class org.apache.hadoop.hbase.master.HMaster
 
listTableNamesByNamespace(RpcController, MasterProtos.ListTableNamesByNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
listTableNamesByNamespace(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Get list of table names by namespace
listTableRegionLocations(Configuration, Connection, TableName) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Lists table regions and locations grouped by region range from META.
listTables() - Method in interface org.apache.hadoop.hbase.client.Admin
List all the userspace tables.
listTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the userspace tables matching the given pattern.
listTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the userspace tables matching the given regular expression.
listTables(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the tables matching the given pattern.
listTables(String, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
List all the tables matching the given pattern.
listTables() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables(Pattern, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables(String, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
listTables() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Use Admin.listTables() instead.
listTableSnapshots(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
listTableSnapshots(Pattern, Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
listTableSnapshots(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List all the completed snapshots matching the given table name regular expression and snapshot name regular expression.
listTableSnapshots(Pattern, Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List all the completed snapshots matching the given table name regular expression and snapshot name regular expression.
LIVE_REGION_SERVERS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
LIVE_REGION_SERVERS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
LIVENODES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
load(Path, String, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Load a coprocessor implementation into the host
load(Path, String, int, Configuration, String[]) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Load a coprocessor implementation into the host
load(Class<?>, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
load(URI) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
load() - Static method in class org.apache.hadoop.hbase.metrics.MetricRegistriesLoader
Creates a MetricRegistries instance using the corresponding MetricRegistries available to ServiceLoader on the classpath.
load(ProcedureStore.ProcedureLoader) - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
 
load(ProcedureStore.ProcedureLoader) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
Load the Procedures in the store.
load(ProcedureStore.ProcedureIterator) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureLoader
Called by the ProcedureStore.load() every time a set of procedures are ready to be executed.
load(Iterator<ProcedureWALFile>, ProcedureStoreTracker, ProcedureWALFormat.Loader) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
 
load(ProcedureStore.ProcedureLoader) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
LOAD_BALANCER_SLOP_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
LOAD_CFS_ON_DEMAND_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
LoadBalancer - Interface in org.apache.hadoop.hbase.master
Makes decisions about the placement and movement of Regions across RegionServers.
LoadBalancerFactory - Class in org.apache.hadoop.hbase.master.balancer
The class that creates a load balancer from a conf.
LoadBalancerFactory() - Constructor for class org.apache.hadoop.hbase.master.balancer.LoadBalancerFactory
 
LoadBalancerTracker - Class in org.apache.hadoop.hbase.zookeeper
Tracks the load balancer state up in ZK
LoadBalancerTracker(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.LoadBalancerTracker
 
loadBlockAndSeekToKey(HFileBlock, Cell, boolean, Cell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
loadBlockAndSeekToKey(HFileBlock, Cell, boolean, Cell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
loadBlockAndSeekToKey(HFileBlock, Cell, boolean, Cell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
loadBloomfilter() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
loadCache() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Contact the servers to load more Results in the cache.
loadClass(String) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
 
loadClass(String, String[]) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
 
loadClass(String) - Method in class org.apache.hadoop.hbase.util.DynamicClassLoader
 
loadColumnFamiliesOnDemand - Variable in class org.apache.hadoop.hbase.client.Query
 
loadDataBlockWithScanInfo(Cell, HFileBlock, boolean, boolean, boolean, DataBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
Return the BlockWithScanInfo, a data structure which contains the Data HFileBlock with other scan info such as the key that starts the next HFileBlock.
loadFileInfo() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
loadFileInfo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
loadFileInfo() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
loadFiles(List<StoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Loads the initial store files into empty StoreFileManager.
loadFiles(List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
loadHdfsRegionDirs() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Scan HDFS for all regions, recording their information into regionInfoMap
loadHFileQueue(Table, Connection, Deque<LoadIncrementalHFiles.LoadQueueItem>, Pair<byte[][], byte[][]>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
Used by the replication sink to load the hfiles from the source cluster.
LoadIncrementalHFiles - Class in org.apache.hadoop.hbase.mapreduce
Tool to load the output of HFileOutputFormat into an existing table.
LoadIncrementalHFiles(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
LoadIncrementalHFiles.LoadQueueItem - Class in org.apache.hadoop.hbase.mapreduce
Represents an HFile waiting to be loaded.
LoadIncrementalHFiles.LoadQueueItem(byte[], Path) - Constructor for class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles.LoadQueueItem
 
loadInstance(Class<?>, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
loadInstance(Class<?>) - Method in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
 
loadProcedures(Configuration) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
 
loadProcedures(Configuration) - Method in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
 
loadProcedures(Configuration) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
 
loadRegionInfoFileContent(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Create a HRegionInfo from the serialized version on-disk.
loadResourceUsingParentFirst(String) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
Determines whether we should attempt to load the given resource using the parent first before attempting to load the resource using this ClassLoader.
loadResultsToCache(Result[], boolean) - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
 
loadSequence - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
loadSpanReceivers() - Method in class org.apache.hadoop.hbase.trace.SpanReceiverHost
Reads the names of classes specified in the hbase.trace.spanreceiver.classes property and instantiates and registers them with the Tracer.
loadSystemCoprocessors(Configuration, String) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Load system coprocessors once only.
loadUserProcedures(Configuration, String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
Load system procedures.
loadValue(byte[], byte[], ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Result
Loads the latest version of the specified column into the provided ByteBuffer.
loadValue(byte[], int, int, byte[], int, int, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Result
Loads the latest version of the specified column into the provided ByteBuffer.
LOCAL - Static variable in class org.apache.hadoop.hbase.LocalHBaseCluster
local mode
LOCAL_COLON - Static variable in class org.apache.hadoop.hbase.LocalHBaseCluster
'local:'
LOCAL_DIR_KEY - Static variable in class org.apache.hadoop.hbase.util.ClassLoaderBase
 
localAddr - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
LocalHBaseCluster - Class in org.apache.hadoop.hbase
This class creates a single process HBase cluster.
LocalHBaseCluster(Configuration) - Constructor for class org.apache.hadoop.hbase.LocalHBaseCluster
Constructor.
LocalHBaseCluster(Configuration, int) - Constructor for class org.apache.hadoop.hbase.LocalHBaseCluster
Constructor.
LocalHBaseCluster(Configuration, int, int) - Constructor for class org.apache.hadoop.hbase.LocalHBaseCluster
Constructor.
LocalHBaseCluster(Configuration, int, int, Class<? extends HMaster>, Class<? extends HRegionServer>) - Constructor for class org.apache.hadoop.hbase.LocalHBaseCluster
Constructor.
LOCALHOST - Static variable in class org.apache.hadoop.hbase.HConstants
Host name of the local machine
LOCALHOST_IP - Static variable in class org.apache.hadoop.hbase.HConstants
 
LOCALITY_SENSITIVE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
Keep locality while generating HFiles for bulkload.
locateRegion(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Find the location of the region of tableName that row lives in.
locateRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Gets the location of the region of regionName.
locateRegion(TableName, byte[], boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
locateRegion(TableName, byte[], boolean, boolean, int) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
locateRegion(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
locateRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
locateRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
locateRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Gets the locations of all regions in the specified table, tableName.
locateRegions(TableName, boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Gets the locations of all regions in the specified table, tableName.
locateRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
locateRegions(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
locateRegions(TableName, boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
locateRegions(byte[], boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
location - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
location - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
 
LOCATION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
lock - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
lockOtherRS(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
Try to set a lock in another region server's znode.
LockTimeoutException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when there is a timeout when trying to acquire a lock
LockTimeoutException() - Constructor for exception org.apache.hadoop.hbase.exceptions.LockTimeoutException
Default constructor
LockTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.LockTimeoutException
 
LOG - Static variable in class org.apache.hadoop.hbase.client.RpcRetryingCaller
 
LOG - Static variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
LOG - Static variable in class org.apache.hadoop.hbase.codec.BaseDecoder
 
LOG - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
static
LOG - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
log - Static variable in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
 
LOG - Static variable in class org.apache.hadoop.hbase.coprocessor.example.RefreshHFilesEndpoint
 
LOG - Static variable in class org.apache.hadoop.hbase.fs.HFileSystem
 
LOG - Static variable in class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
 
LOG - Static variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
LOG - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
LOG - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
LOG - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
 
LOG - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSplit
Deprecated.
LOG variable would be made private.
LOG - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
LOG - Static variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
log - Variable in class org.apache.hadoop.hbase.wal.DefaultWALProvider
 
LOG - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
LOG2_SQUARED - Static variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Used in computing the optimal Bloom filter size.
LOG_BAD_LINES_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
LOG_PER_ROW_COUNT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
 
LOG_REPLAY_WAIT_REGION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key that specifies timeout value to wait for a region ready
LOG_SCANNER_ACTIVITY - Static variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
LOG_SCANNER_LATENCY_CUTOFF - Static variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
LogCleaner - Class in org.apache.hadoop.hbase.master.cleaner
This Chore, every time it runs, will attempt to delete the WALs in the old logs folder.
LogCleaner(int, Stoppable, Configuration, FileSystem, Path, DirScanPool) - Constructor for class org.apache.hadoop.hbase.master.cleaner.LogCleaner
 
logCloseRequested() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
 
logCloseRequested() - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
The WAL is about to close.
logDir - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
logFileSystemState(Log) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
logFileSystemState(FileSystem, Path, Log) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Log the current state of the filesystem from a certain root directory
LOGGING_EXCEPTION_HANDLER - Static variable in class org.apache.hadoop.hbase.util.Threads
 
login(UserProvider, String) - Method in class org.apache.hadoop.hbase.master.HMaster
For compatibility, if failed with regionserver credentials, try the master one
login(UserProvider, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
login(Configuration, String, String, String) - Static method in class org.apache.hadoop.hbase.security.User
Log in the current process using the given configuration keys for the credential file and login principal.
login(Configuration, String, String, String) - Static method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
Obtain credentials for the current process using the configured Kerberos keytab file and principal.
login(String, String, String) - Method in class org.apache.hadoop.hbase.security.UserProvider
Log in the current process using the given configuration keys for the credential file and login principal.
loginClient(Configuration, String, String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Log in the current zookeeper client using the given configuration keys for the credential file and login principal.
loginServer(Configuration, String, String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Log in the current zookeeper server process using the given configuration keys for the credential file and login principal.
logJVMInfo() - Static method in class org.apache.hadoop.hbase.util.ServerCommandLine
Log information about the currently running JVM.
LogLevel - Class in org.apache.hadoop.hbase.http.log
Change log level in runtime.
LogLevel() - Constructor for class org.apache.hadoop.hbase.http.log.LogLevel
 
LogLevel.Servlet - Class in org.apache.hadoop.hbase.http.log
A servlet implementation
LogLevel.Servlet() - Constructor for class org.apache.hadoop.hbase.http.log.LogLevel.Servlet
 
LogMonitoring - Class in org.apache.hadoop.hbase.monitoring
Utility functions for reading the log4j logs that are being written by HBase.
LogMonitoring() - Constructor for class org.apache.hadoop.hbase.monitoring.LogMonitoring
 
logPositionAndCleanOldLogs(Path, String, long, boolean, boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Provide the id of the peer and a log key and this method will figure which wal it belongs to and will log, for this region server, the current position.
logProcessInfo(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerCommandLine
Logs information about the currently running JVM process including the environment variables.
logResult(AuthResult) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
 
LogRoller - Class in org.apache.hadoop.hbase.regionserver
Runs periodically to determine if the WAL should be rolled.
LogRoller(Server, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.LogRoller
 
logRollRequested(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
 
logRollRequested(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
 
logRollRequested(boolean) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
A request was made that the WAL be rolled.
logSeqNum - Variable in class org.apache.hadoop.hbase.wal.WALKey
 
logSplit(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
A dead server's wals have been split so that all the regions used to be open on it can be safely assigned now.
logSplit(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
Log split is done for a given region, so it is assignable now.
logStats() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
logStats() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
logThreadInfo(Log, String, long) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
Log the current thread stacks at INFO level.
logVersion() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
 
logZKTree(String, String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
Helper method to print the current state of the ZK tree.
logZKTree(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Recursively print the current state of ZK (non-transactional)
logZKTree(ZooKeeperWatcher, String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Helper method to print the current state of the ZK tree.
LONG_7_RIGHT_BITS_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVLongTool
 
LONG_8TH_BIT_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVLongTool
 
LongAdder - Class in org.apache.hadoop.hbase.util
One or more variables that together maintain an initially zero long sum.
LongAdder() - Constructor for class org.apache.hadoop.hbase.util.LongAdder
Creates a new adder with initial sum of zero.
LongColumnInterpreter - Class in org.apache.hadoop.hbase.client.coprocessor
a concrete column interpreter implementation.
LongColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
LongComparator - Class in org.apache.hadoop.hbase.filter
A long comparator which numerical compares against the specified byte array
LongComparator(long) - Constructor for class org.apache.hadoop.hbase.filter.LongComparator
 
LongEncoder - Class in org.apache.hadoop.hbase.codec.prefixtree.encode.other
Used to de-duplicate, sort, minimize/diff, and serialize timestamps and mvccVersions from a collection of Cells.
LongEncoder() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
construct
longFitsIn(long) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Check how many bytes are required to store value.
LongTermArchivingHFileCleaner - Class in org.apache.hadoop.hbase.backup.example
BaseHFileCleanerDelegate that only cleans HFiles that don't belong to a table that is currently being archived.
LongTermArchivingHFileCleaner() - Constructor for class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
 
longValue() - Method in class org.apache.hadoop.hbase.util.LongAdder
Equivalent to LongAdder.sum().
LossyCounting - Class in org.apache.hadoop.hbase.util
LossyCounting utility, bounded data structure that maintains approximate high frequency elements in data stream.
LossyCounting(double, LossyCounting.LossyCountingListener) - Constructor for class org.apache.hadoop.hbase.util.LossyCounting
 
LossyCounting(LossyCounting.LossyCountingListener) - Constructor for class org.apache.hadoop.hbase.util.LossyCounting
 
LossyCounting.LossyCountingListener - Interface in org.apache.hadoop.hbase.util
 
LOW_REPLICA_ROLL_REQUESTED - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
LOW_REPLICA_ROLL_REQUESTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
lower(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
lowerEntry(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
lowerKey(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
LOWESTKEY - Static variable in class org.apache.hadoop.hbase.KeyValue
Lowest possible key.
LPAREN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for LPAREN
LPAREN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
LPAREN Array
LPAREN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
LruBlockCache - Class in org.apache.hadoop.hbase.io.hfile
A block cache implementation that is memory-aware using HeapSize, memory-bound using an LRU eviction algorithm, and concurrent: backed by a ConcurrentHashMap and with a non-blocking eviction thread giving constant-time LruBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable, boolean, boolean) and LruBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean) operations.
LruBlockCache(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Default constructor.
LruBlockCache(long, long, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Constructor used for testing.
LruBlockCache(long, long, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
LruBlockCache(long, long, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
LruBlockCache(long, long, boolean, int, float, int, float, float, float, float, float, float, boolean, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Configurable constructor.
lruCache - Variable in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
LruCachedBlock - Class in org.apache.hadoop.hbase.io.hfile
Represents an entry in the LruBlockCache.
LruCachedBlock(BlockCacheKey, Cacheable, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
LruCachedBlock(BlockCacheKey, Cacheable, long, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
LruCachedBlockQueue - Class in org.apache.hadoop.hbase.io.hfile
A memory-bound queue that will grow until an element brings total size >= maxSize.
LruCachedBlockQueue(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
 
LRUDictionary - Class in org.apache.hadoop.hbase.io.util
WALDictionary using an LRU eviction algorithm.
LRUDictionary() - Constructor for class org.apache.hadoop.hbase.io.util.LRUDictionary
 
LruHashMap<K extends HeapSize,V extends HeapSize> - Class in org.apache.hadoop.hbase.regionserver
The LruHashMap is a memory-aware HashMap with a configurable maximum memory footprint.
LruHashMap(int, float, long) - Constructor for class org.apache.hadoop.hbase.regionserver.LruHashMap
Constructs a new, empty map with the specified initial capacity, load factor, and maximum memory usage.
LruHashMap(int, float) - Constructor for class org.apache.hadoop.hbase.regionserver.LruHashMap
Constructs a new, empty map with the specified initial capacity and load factor, and default maximum memory usage.
LruHashMap(int) - Constructor for class org.apache.hadoop.hbase.regionserver.LruHashMap
Constructs a new, empty map with the specified initial capacity and with the default load factor and maximum memory usage.
LruHashMap(long) - Constructor for class org.apache.hadoop.hbase.regionserver.LruHashMap
Constructs a new, empty map with the specified maximum memory usage and with default initial capacity and load factor.
LruHashMap() - Constructor for class org.apache.hadoop.hbase.regionserver.LruHashMap
Constructs a new, empty map with the default initial capacity, load factor and maximum memory usage.
LruHashMap.Entry<K extends HeapSize,V extends HeapSize> - Class in org.apache.hadoop.hbase.regionserver
Entry to store key/value mappings.

M

MAGIC_LENGTH - Static variable in enum org.apache.hadoop.hbase.io.hfile.BlockType
 
main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.BufferedMutatorExample
 
main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample
 
main(String[]) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
For debugging.
main(String[]) - Static method in class org.apache.hadoop.hbase.hbtop.HBTop
 
main(String[]) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
 
main(String[]) - Static method in class org.apache.hadoop.hbase.http.log.LogLevel
A command line implementation
main(String[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
main(String[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
 
main(String[]) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
Test things basically work.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.Driver
 
main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.RowCounter
 
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CopyTable
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Driver
 
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Export
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.HashTable
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
 
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SampleUploader
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SyncTable
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
Main entry point.
main(String[]) - Static method in class org.apache.hadoop.hbase.master.HMaster
 
main(String[]) - Static method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
 
main(String[]) - Static method in class org.apache.hadoop.hbase.migration.UpgradeTo96
 
main(String[]) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
 
main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionTool
 
main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Code to help figure if our approximation of object heap sizes is close enough.
main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Facility for dumping and compacting catalog tables.
main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.ShutdownHook
Main to test basic functionality.
main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.Compressor
Command line tool to compress and uncompress WALs.
main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
Pass one or more log file names and it will either dump out a text version on stdout or split the specified log files.
main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
Deprecated.
 
main(String[]) - Static method in class org.apache.hadoop.hbase.replication.master.TableCFsUpdater
 
main(String[]) - Static method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
Main
main(String[]) - Static method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
Main program
main(String[]) - Static method in class org.apache.hadoop.hbase.rest.RESTDemoClient
 
main(String[]) - Static method in class org.apache.hadoop.hbase.rest.RESTServer
The main method for the HBase rest server.
main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
 
main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Deprecated.
 
main(String[]) - Static method in class org.apache.hadoop.hbase.thrift.DemoClient
 
main(String[]) - Static method in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
 
main(String[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftServer
 
main(String[]) - Static method in class org.apache.hadoop.hbase.thrift2.DemoClient
 
main(String[]) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftServer
Start up the Thrift2 server.
main(String[]) - Static method in class org.apache.hadoop.hbase.tool.CanaryTool
 
main(String[]) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
 
main(String[]) - Static method in class org.apache.hadoop.hbase.util.GetJavaProperty
 
main(String[]) - Static method in class org.apache.hadoop.hbase.util.HBaseConfTool
 
main(String[]) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
Main program
main(String[]) - Static method in class org.apache.hadoop.hbase.util.hbck.OfflineMetaRepair
Main program
main(String[]) - Static method in class org.apache.hadoop.hbase.util.HFileV1Detector
 
main(String[]) - Static method in class org.apache.hadoop.hbase.util.JenkinsHash
Compute the hash of the specified file
main(String[]) - Static method in class org.apache.hadoop.hbase.util.JSONBean
 
main(String[]) - Static method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
Simple 'main' to facilitate manual testing of the pause monitor.
main(String[]) - Static method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
 
main(String[]) - Static method in class org.apache.hadoop.hbase.util.Merge
 
main(String[]) - Static method in class org.apache.hadoop.hbase.util.Random64
Random64 is a pseudorandom algorithm(LCG).
main(String[]) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter
The main function for the RegionSplitter application.
main(String[]) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
 
main(String[]) - Static method in class org.apache.hadoop.hbase.util.ZKDataMigrator
 
main(String[]) - Static method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
 
main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
Parse ZooKeeper configuration from HBase XML config and run a QuorumPeer.
main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZkAclReset
 
main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKServerTool
Run the tool.
main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperMainServer
Run the tool.
main(String[]) - Static method in class org.apache.hbase.archetypes.exemplars.client.HelloHBase
 
main(String[]) - Static method in class org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
 
MAJOR_COMPACTED_CELLS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTED_CELLS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTED_CELLS_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTED_CELLS_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTED_INPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTED_INPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTED_OUTPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTED_OUTPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTION_DROP_CACHE - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
MAJOR_COMPACTION_INPUT_FILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTION_INPUT_FILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTION_INPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTION_INPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTION_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Major compaction flag in FileInfo
MAJOR_COMPACTION_OUTPUT_FILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTION_OUTPUT_FILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTION_OUTPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTION_OUTPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTION_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for how often a region should should perform a major compaction
MAJOR_COMPACTION_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_COMPACTION_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAJOR_VERSION - Static variable in exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
 
majorCompact(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Major compact a table.
majorCompact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Major compact a column family within a table.
majorCompact(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a table.
majorCompact(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
majorCompact(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
majorCompact(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a column family within a table.
majorCompact(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
majorCompact(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
majorCompact(ByteBuffer, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
majorCompact(ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
majorCompact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
majorCompact(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
 
majorCompact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
MajorCompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
Query matcher for major compaction.
MajorCompactionScanQueryMatcher(ScanInfo, DeleteTracker, long, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.MajorCompactionScanQueryMatcher
 
majorCompactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Major compact a table or an individual region.
majorCompactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Major compact a column family within region.
majorCompactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a table or an individual region.
majorCompactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a column family within region.
majorRangeFromRow - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
 
majorRangeToRow - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
 
makeColumn(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
Makes a column in family:qualifier form from separate byte arrays.
makeDeleteFromRegionInfo(HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Generates and returns a Delete containing the region info for the catalog table
makeDeleteFromRegionInfo(HRegionInfo, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Generates and returns a Delete containing the region info for the catalog table
makeFilter(QuotaFilter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
converts quotafilter to serializeable filterlists.
makeGetForNamespaceQuotas(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
makeGetForTableQuotas(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
makeGetForUserQuotas(String, Iterable<TableName>, Iterable<String>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
 
makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
 
makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
 
makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
 
makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
 
makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
 
makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
 
makeNamespaceDirs() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
Create the system and default namespaces dirs
makePutFromRegionInfo(HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Generates and returns a Put containing the region into for the catalog table
makePutFromRegionInfo(HRegionInfo, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Generates and returns a Put containing the region into for the catalog table
makeRenderer() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
makeRenderer(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
 
makeRenderer(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
 
makeRenderer(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
makeRenderer(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
 
makeRenderer(CacheConfig, Configuration) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
 
makeRenderer(CacheConfig, Configuration, String, String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
 
makeRenderer(HRegionServer, List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
 
makeRenderer(HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
makeRenderer(MetricsRegionServerWrapper, MetricsHBaseServerWrapper) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
 
makeScan(QuotaFilter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
makeZKProps(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
Make a Properties object holding ZooKeeper config.
ManualEnvironmentEdge - Class in org.apache.hadoop.hbase.util
An environment edge that uses a manually set value.
ManualEnvironmentEdge() - Constructor for class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
 
map(ImmutableBytesWritable, Result, OutputCollector<ImmutableBytesWritable, Result>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Extract the grouping columns from value to construct a new key.
map(ImmutableBytesWritable, Result, OutputCollector<ImmutableBytesWritable, Result>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
Pass the key, value to reduce
map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Result>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Extract the grouping columns from value to construct a new key.
map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, ImmutableBytesWritable>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
 
map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Result>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
Pass the key, value to reduce.
map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
 
map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueImporter
 
map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, Import.KeyValueWritableComparable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueSortImporter
 
map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map
 
map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
Map method that compares every scanned row with the equivalent from a distant cluster.
map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
 
map(LongWritable, Text, Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
Convert a line of TSV text into an HBase table row.
map(LongWritable, Text, Mapper<LongWritable, Text, ImmutableBytesWritable, Text>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
Convert a line of TSV text into an HBase table row.
map(WALKey, WALEdit, Mapper<WALKey, WALEdit, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
 
MAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for entry in map
mapKey(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
mapKey(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
MAPPER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
 
MAPPER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
MAPREDUCE_INPUT_AUTOBALANCE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Specify if we enable auto-balance to set number of mappers in M/R jobs.
MapreduceDependencyClasspathTool - Class in org.apache.hadoop.hbase.util
Generate a classpath string containing any jars required by mapreduce jobs.
MapreduceDependencyClasspathTool() - Constructor for class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
 
mark(int) - Method in class org.apache.hadoop.hbase.io.LimitInputStream
 
mark() - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
 
mark(long) - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
 
mark() - Method in interface org.apache.hadoop.hbase.metrics.Meter
Records one occurrence.
mark(long) - Method in interface org.apache.hadoop.hbase.metrics.Meter
Records events occurrences.
markAfterLast() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
markBeforeFirst() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
markCompactedAway() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
Marks the status of the file as compactedAway.
markComplete(String) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
 
markComplete(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
markCorrupted(Path, String, FileSystem) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
marks log file as corrupted
markCorrupted(Path, String, FileSystem) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
 
markCorrupted(Path, String, FileSystem) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
markHead() - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
 
markRegionsOffline(MasterProcedureEnv, TableName, Boolean) - Static method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
Mark regions of the table offline with retries
markRegionsOnline(MasterProcedureEnv, TableName, Boolean) - Static method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
Mark offline regions of the table online with retry
markRegionsRecovering(ServerName, Set<HRegionInfo>) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Mark regions in recovering state for distributed log replay
markRegionsRecovering(ServerName, Set<HRegionInfo>) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
Create znodes /hbase/recovering-regions/[region_ids...]/[failed region server names ...] for all regions of the passed in region servers
markRegionsRecovering(ServerName, Set<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
 
markTableAsDeleted(TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Tries to remove the queue and the table-lock of the specified table.
MASK_FOR_LOWER_INT_IN_LONG - Static variable in class org.apache.hadoop.hbase.util.Bytes
Mask to apply to a long to reveal the lower int only.
MASTER - Static variable in class org.apache.hadoop.hbase.master.HMaster
 
master - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
MASTER_ACTIVE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
MASTER_ACTIVE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
MASTER_CLOSE_REGION_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_CLOSE_REGION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
MASTER_FINISHED_INITIALIZATION_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
MASTER_FINISHED_INITIALIZATION_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
MASTER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_HFILE_CLEANER_PLUGINS - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
MASTER_HOSTNAME_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
MASTER_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for what master implementation to use.
MASTER_INFO_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for master web API port
MASTER_LOG_REPLAY_OPS_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_LOG_REPLAY_OPS_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_META_SERVER_OPERATIONS_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_META_SERVER_OPERATIONS_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_OPEN_REGION_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
Configurations for master executor services.
MASTER_OPEN_REGION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for port master listens on.
MASTER_PROCEDURE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
 
MASTER_PROCEDURE_LOGDIR - Static variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureConstants
Used to construct the name of the log directory for master procedures
MASTER_PROCEDURE_THREADS - Static variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureConstants
Number of threads used by the procedure executor
MASTER_SERVER_OPERATIONS_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_SERVER_OPERATIONS_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
MASTER_SNAPSHOT_TIMEOUT_MILLIS - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
 
MASTER_START_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
MASTER_START_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
MASTER_TYPE_BACKUP - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the master type being backup (waits for primary to go inactive).
MasterAddressTracker - Class in org.apache.hadoop.hbase.zookeeper
Manages the location of the current active Master for the RegionServer.
MasterAddressTracker(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Construct a master address listener with the specified zookeeper reference.
MasterAnnotationReadingPriorityFunction - Class in org.apache.hadoop.hbase.master
Priority function specifically for the master.
MasterAnnotationReadingPriorityFunction(RSRpcServices) - Constructor for class org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
 
MasterAnnotationReadingPriorityFunction(RSRpcServices, Class<? extends RSRpcServices>) - Constructor for class org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
 
MasterCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
 
MasterCoprocessorHost - Class in org.apache.hadoop.hbase.master
Provides the coprocessor framework and environment for master oriented operations.
MasterCoprocessorHost(MasterServices, Configuration) - Constructor for class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
MasterCoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
Provides clients with an RPC connection to call coprocessor endpoint Services against the active master.
MasterCoprocessorRpcChannel(ClusterConnection) - Constructor for class org.apache.hadoop.hbase.ipc.MasterCoprocessorRpcChannel
 
MasterDDLOperationHelper - Class in org.apache.hadoop.hbase.master.procedure
Helper class for schema change procedures
MasterDumpServlet - Class in org.apache.hadoop.hbase.master
 
MasterDumpServlet() - Constructor for class org.apache.hadoop.hbase.master.MasterDumpServlet
 
MasterFileSystem - Class in org.apache.hadoop.hbase.master
This class abstracts a bunch of operations the HMaster needs to interact with the underlying file system, including splitting log files, checking file system status, etc.
MasterFileSystem(Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.MasterFileSystem
 
MasterFlushTableProcedureManager - Class in org.apache.hadoop.hbase.procedure.flush
 
MasterFlushTableProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
 
MasterMaintenanceModeTracker - Class in org.apache.hadoop.hbase.zookeeper
Tracks the master Maintenance Mode via ZK.
MasterMaintenanceModeTracker(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
 
masterMaintZNode - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
MasterNotRunningException - Exception in org.apache.hadoop.hbase
Thrown if the master is not running
MasterNotRunningException() - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
default constructor
MasterNotRunningException(String) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
Constructor
MasterNotRunningException(Exception) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
Constructor taking another exception.
MasterNotRunningException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
 
MasterObserver - Interface in org.apache.hadoop.hbase.coprocessor
Defines coprocessor hooks for interacting with operations on the HMaster process.
MasterProcedureConstants - Class in org.apache.hadoop.hbase.master.procedure
 
MasterProcedureEnv - Class in org.apache.hadoop.hbase.master.procedure
 
MasterProcedureEnv(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
MasterProcedureEnv.MasterProcedureStoreListener - Class in org.apache.hadoop.hbase.master.procedure
 
MasterProcedureEnv.MasterProcedureStoreListener(HMaster) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.MasterProcedureStoreListener
 
MasterProcedureEnv.WALStoreLeaseRecovery - Class in org.apache.hadoop.hbase.master.procedure
 
MasterProcedureEnv.WALStoreLeaseRecovery(HMaster) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.WALStoreLeaseRecovery
 
MasterProcedureManager - Class in org.apache.hadoop.hbase.procedure
A life-cycle management interface for globally barriered procedures on master.
MasterProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.MasterProcedureManager
 
MasterProcedureManagerHost - Class in org.apache.hadoop.hbase.procedure
Provides the globally barriered procedure framework and environment for master oriented operations.
MasterProcedureManagerHost() - Constructor for class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
 
MasterProcedureScheduler - Class in org.apache.hadoop.hbase.master.procedure
ProcedureRunnableSet for the Master Procedures.
MasterProcedureScheduler(Configuration, TableLockManager) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
MasterProcedureScheduler.ProcedureEvent - Class in org.apache.hadoop.hbase.master.procedure
 
MasterProcedureScheduler.ProcedureEvent(String) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler.ProcedureEvent
 
MasterProcedureScheduler.ServerQueue - Class in org.apache.hadoop.hbase.master.procedure
 
MasterProcedureScheduler.ServerQueue(ServerName) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler.ServerQueue
 
MasterProcedureScheduler.TableQueue - Class in org.apache.hadoop.hbase.master.procedure
 
MasterProcedureScheduler.TableQueue(TableName, MasterProcedureScheduler.NamespaceQueue, int) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler.TableQueue
 
MasterProcedureUtil - Class in org.apache.hadoop.hbase.master.procedure
 
MasterProcedureUtil.NonceProcedureRunnable - Class in org.apache.hadoop.hbase.master.procedure
Helper Runnable used in conjunction with submitProcedure() to deal with submitting procs with nonce.
MasterProcedureUtil.NonceProcedureRunnable(MasterServices, long, long) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
 
MasterQuotaManager - Class in org.apache.hadoop.hbase.quotas
Master Quota Manager.
MasterQuotaManager(MasterServices) - Constructor for class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
MasterRpcServices - Class in org.apache.hadoop.hbase.master
Implements the master RPC services.
MasterRpcServices(HMaster) - Constructor for class org.apache.hadoop.hbase.master.MasterRpcServices
 
masterServerName - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
masterServices - Variable in class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
MasterServices - Interface in org.apache.hadoop.hbase.master
Services Master supplies
MasterSnapshotVerifier - Class in org.apache.hadoop.hbase.master.snapshot
General snapshot verification on the master.
MasterSnapshotVerifier(MasterServices, HBaseProtos.SnapshotDescription, FileSystem) - Constructor for class org.apache.hadoop.hbase.master.snapshot.MasterSnapshotVerifier
 
MasterStatusServlet - Class in org.apache.hadoop.hbase.master
The servlet responsible for rendering the index page of the master.
MasterStatusServlet() - Constructor for class org.apache.hadoop.hbase.master.MasterStatusServlet
 
MasterStatusTmpl - Class in org.apache.hadoop.hbase.tmpl.master
 
MasterStatusTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
MasterStatusTmpl(String) - Constructor for class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
MasterStatusTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
MasterStatusTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.master
 
MasterStatusTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
MasterStatusTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.master
 
MasterStatusTmplImpl - Class in org.apache.hadoop.hbase.tmpl.master
 
MasterStatusTmplImpl(TemplateManager, MasterStatusTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmplImpl
 
match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.LegacyScanQueryMatcher
Deprecated.
 
match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.MajorCompactionScanQueryMatcher
 
match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.MinorCompactionScanQueryMatcher
 
match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
 
match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
 
match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
Determines if the caller should do one of several things: seek/skip to the next row (MatchCode.SEEK_NEXT_ROW) seek/skip to the next column (MatchCode.SEEK_NEXT_COL) include the current KeyValue (MatchCode.INCLUDE) ignore the current KeyValue (MatchCode.SKIP) got to the next row (MatchCode.DONE)
match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher
 
matchColumn(Cell, long, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
matchedColumn - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
matcher - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
matches(String) - Method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
 
matchesFamily(TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
Returns true if this permission matches the given column family at least.
matchesFamilyQualifier(TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
Returns if the given permission matches the given qualifier.
matchesToken(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
matchingColumn(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingColumn(Cell, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingColumn(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingFamily(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingFamily(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingFamily(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingNode - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
 
matchingQualifier(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingQualifier(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingQualifier(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingRow(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingRow(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingRow(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingRowColumn(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Compares the row and column of two keyvalues for equality
matchingRowColumn(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Compares the row and column of two keyvalues for equality
matchingRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Compares the row of two keyvalues for equality
matchingRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Compare rows.
matchingTimestamp(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingType(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingValue(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchingValue(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
 
matchPermission(User, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Returns true if the given user has a TablePermission matching up to the column family portion of a permission.
matchPermission(User, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
matchVisibility(List<Tag>, Byte, List<Tag>, Byte) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
matchVisibility(List<Tag>, Byte, List<Tag>, Byte) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
System uses this for deciding whether a Cell can be deleted by matching visibility expression in Delete mutation and the cell in consideration.
max(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the maximum value of a column for a given column family for the given range.
max(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the maximum value of a column for a given column family for the given range.
max - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
MAX_AVERAGE_REGION_SIZE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
In auto-balance, we split input by ave region size, if calculated region size is too big, we can set it.
MAX_BACKOFF_KEY - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
MAX_BYTES - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
MAX_CACHED_CONNECTION_INSTANCES - Static variable in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
MAX_CHUNK_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
The maximum size guideline for index blocks (both leaf, intermediate, and root).
MAX_COMPACTION_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
MAX_COMPACTION_QUEUE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
MAX_FAMILY_LENGTH - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
MAX_FILES_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
The maximum number of files to compact within a stripe; same as for regular compaction.
MAX_FILES_PER_REGION_PER_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by HBase Shell interface to access this metadata attribute which denotes the maximum size of the store file after which a region split occurs
MAX_FLUSH_PER_CHANGES - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
The following MAX_FLUSH_PER_CHANGES is large enough because each KeyValue has 20+ bytes overhead.
MAX_FLUSH_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
MAX_FLUSH_QUEUE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
MAX_FORMAT_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Maximum supported HFile format version
MAX_KEYVALUE_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
MAX_KEYVALUE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
MAX_MEMSTORE_TS_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Max memstore (mvcc) timestamp in FileInfo
MAX_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
MAX_MINOR_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
 
MAX_PRECISION - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
Max precision guaranteed to fit into a long.
MAX_QUEUED_REQUESTS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
The maximum number of pending connections waiting in the queue.
MAX_REGION_SPLIT_IMBALANCE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
When splitting region, the maximum size imbalance to allow in an attempt to split at a stripe boundary, so that no files go to both regions.
MAX_REQUEST_SIZE - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
MAX_RETRIES_BEFORE_ROLL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
MAX_ROW_LENGTH - Static variable in class org.apache.hadoop.hbase.HConstants
Max length a row can have because of the limitation in TFile.
MAX_RUNNING_TIME_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
MAX_SEQ_ID_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Max Sequence ID in FileInfo
MAX_SERVER_PER_MESSAGE - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
We want to limit the size of the protobuf message sent, do fit into a single packet.
MAX_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
MAX_STEPS_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
MAX_STORE_FILE_AGE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAX_STORE_FILE_AGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MAX_SYNC_FAILURE_ROLL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
MAX_TAG_LENGTH - Static variable in class org.apache.hadoop.hbase.Tag
 
MAX_TAGS_LEN - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
MAX_TASKS_KEY - Static variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
MAX_TIER_AGE_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory
 
MAX_VALUE_BYTES - Static variable in class org.apache.hadoop.hbase.util.vint.UVIntTool
 
MAX_VALUE_BYTES - Static variable in class org.apache.hadoop.hbase.util.vint.UVLongTool
 
MAX_WORKER_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
The maximum size of the thread pool.
maxColumn - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
maxColumnInclusive - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
maxDelta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
maxElementLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
MAXHEAPSIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
maxIdleTime - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
MAXIMUM_KEY_LENGTH - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Maximum length of key in HFile.
MAXIMUM_VALUE_LENGTH - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum value length, enforced on KeyValue construction
maxKeyCount - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
Maximum key count after compaction (for blooms)
maxKeys - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Max Keys expected for the bloom
maxKeyValueSize(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Override the maximum key-value size specified by the provided Connection's Configuration instance, via the configuration key hbase.client.keyvalue.maxsize.
maxMemstoreTS - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
 
maxMVCCReadpoint - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
Latest memstore read point found in any of the involved files
maxQualifierLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
maxReadPointToTrackVersions - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
readPoint over which the KVs are unconditionally included
maxRetries - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
maxRowLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
maxRowSize - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
maxScannerResultSize - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
maxSeqId - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
The last key in the files we're compacting.
maxStamp - Variable in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
maxTagLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
maxTagsLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
maxTagsLength - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
Max tags length
maxThroughputLowerBound - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
maxThroughputUpperBound - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
maxValueForNumBytes(int) - Static method in class org.apache.hadoop.hbase.util.vint.UFIntTool
 
maxValueLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
maxVersions - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
maxVersions - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
maxVersions - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
MAXVERSIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
MAXVERSIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
mayHaveClusterIssues() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
mayHaveMoreCellsInRow() - Method in class org.apache.hadoop.hbase.client.Result
For scanning large rows, the RS may choose to return the cells chunk by chunk to prevent OOM or timeout.
mBeanServer - Variable in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
MBean server.
MBeanSource - Interface in org.apache.hadoop.hbase.metrics
Object that will register an mbean with the underlying metrics implementation.
MBeanSourceImpl - Class in org.apache.hadoop.hbase.metrics
Hadoop2 metrics2 implementation of an object that registers MBeans.
MBeanSourceImpl() - Constructor for class org.apache.hadoop.hbase.metrics.MBeanSourceImpl
 
MBeanUtil - Class in org.apache.hadoop.hbase.util
 
MBeanUtil() - Constructor for class org.apache.hadoop.hbase.util.MBeanUtil
 
md - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
MD5_HEX_LENGTH - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
MD5Hash - Class in org.apache.hadoop.hbase.util
Utility class for MD5 MD5 hash produces a 128-bit digest.
MD5Hash() - Constructor for class org.apache.hadoop.hbase.util.MD5Hash
 
MEAN_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
mechanismName - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
 
median(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handler for calling the median method for a given cf-cq combination.
median(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handler for calling the median method for a given cf-cq combination.
MEDIAN_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
member - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
 
MEMCACHED_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
MEMCACHED_DEFAULT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
MEMCACHED_OPTIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
MEMCACHED_OPTIMIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
MEMCACHED_OPTIMIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
MEMCACHED_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
MemcachedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
Class to store blocks into memcached.
MemcachedBlockCache(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
MemoryBoundedLogMessageBuffer - Class in org.apache.hadoop.hbase.monitoring
A size-bounded repository of alerts, which are kept in a linked list.
MemoryBoundedLogMessageBuffer(long) - Constructor for class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
 
memstore - Variable in class org.apache.hadoop.hbase.regionserver.HStore
 
MemStore - Interface in org.apache.hadoop.hbase.regionserver
The MemStore holds in-memory modifications to the Store.
MEMSTORE_FLUSH_PER_CHANGES - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
Conf key to force a flush if there are already enough changes for one region in memstore
MEMSTORE_FLUSHSIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by HBase Shell interface to access this metadata attribute which represents the maximum size of the memstore after which its contents are flushed onto the disk
MEMSTORE_PERIODIC_FLUSH_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
Conf key for the periodic flush interval
MEMSTORE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MEMSTORE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
MEMSTORE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MEMSTORE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
MEMSTORE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
 
MEMSTORE_SIZE_LOWER_LIMIT_KEY - Static variable in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
 
MEMSTORE_SIZE_LOWER_LIMIT_OLD_KEY - Static variable in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
 
MEMSTORE_SIZE_MAX_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
MEMSTORE_SIZE_MIN_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
MEMSTORE_SIZE_OLD_KEY - Static variable in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
 
MemStoreChunkPool - Class in org.apache.hadoop.hbase.regionserver
A pool of HeapMemStoreLAB.Chunk instances.
MemStoreLAB - Interface in org.apache.hadoop.hbase.regionserver
A memstore-local allocation buffer.
MEMSTORESIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
MemStoreSnapshot - Class in org.apache.hadoop.hbase.regionserver
Holds details of the snapshot taken on a MemStore.
MemStoreSnapshot(long, int, long, TimeRangeTracker, KeyValueScanner, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
 
memstoreTS - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
merge(Configuration, Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Merge two configurations.
merge(ProcedureStoreTracker.BitSetNode) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
merge(HRegion, HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Merge two regions whether they are adjacent or not.
Merge - Class in org.apache.hadoop.hbase.util
Utility that can merge any two regions in the same table: adjacent, overlapping or disjoint.
Merge() - Constructor for class org.apache.hadoop.hbase.util.Merge
default constructor
Merge(Configuration) - Constructor for class org.apache.hadoop.hbase.util.Merge
 
MERGE_PLAN_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
MERGE_PLAN_COUNT_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
MERGE_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
MERGE_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
MERGE_TRANSACTION_IMPL_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionFactory
 
MERGEA_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The lower-half merge region column qualifier
mergeAdjacent(HRegion, HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Merge two HRegions.
MERGEB_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The upper-half merge region column qualifier
mergeDelimitedFrom(Message.Builder, InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeDelimitedFrom avoids the hard-coded 64MB limit for decoding buffers
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
mergeFrom(BulkDeleteProtos.BulkDeleteRequest) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
mergeFrom(BulkDeleteProtos.BulkDeleteResponse) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
mergeFrom(ExampleProtos.CountRequest) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
mergeFrom(ExampleProtos.CountResponse) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
mergeFrom(Message.Builder, InputStream, int) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers where the message size is known
mergeFrom(Message.Builder, InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers where the message size is not known
mergeFrom(Message.Builder, ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with ByteStrings
mergeFrom(Message.Builder, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with byte arrays
mergeFrom(Message.Builder, byte[], int, int) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with byte arrays
mergeFrom(Message.Builder, CodedInputStream, int) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
mergeFrom(CellMessage.Cell) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
mergeFrom(CellSetMessage.CellSet) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
mergeFrom(CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
mergeFrom(ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
mergeFrom(ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
 
mergeFrom(NamespacePropertiesMessage.NamespaceProperties) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
 
mergeFrom(NamespacePropertiesMessage.NamespaceProperties.Property) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
 
mergeFrom(NamespacesMessage.Namespaces) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
mergeFrom(ScannerMessage.Scanner) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
mergeFrom(StorageClusterStatusMessage.StorageClusterStatus) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
mergeFrom(StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
mergeFrom(StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
mergeFrom(TableInfoMessage.TableInfo) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
mergeFrom(TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
mergeFrom(TableListMessage.TableList) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
mergeFrom(TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
mergeFrom(TableSchemaMessage.TableSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
mergeFrom(VersionMessage.Version) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
mergeLocations(RegionLocations) - Method in class org.apache.hadoop.hbase.RegionLocations
Merges this RegionLocations list with the given list assuming same range, and keeping the most up to date version of the HRegionLocation entries from either list according to seqNum.
MergeNormalizationPlan - Class in org.apache.hadoop.hbase.master.normalizer
Normalization plan to merge regions (smallest region in the table with its smallest neighbor).
MergeNormalizationPlan(HRegionInfo, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.master.normalizer.MergeNormalizationPlan
 
mergeRegionDirs(Path, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Merge hdfs data by moving from contained HbckInfo into targetRegionDir.
MergeRegionException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when something is wrong in trying to merge two regions.
MergeRegionException() - Constructor for exception org.apache.hadoop.hbase.exceptions.MergeRegionException
default constructor
MergeRegionException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.MergeRegionException
Constructor
mergeRegions(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Merge two regions.
mergeRegions(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Merge two regions.
mergeRegions(Connection, HRegionInfo, HRegionInfo, HRegionInfo, ServerName, int, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Merge the two regions into one in an atomic operation.
mergeRegions(RpcController, AdminProtos.AdminService.BlockingInterface, HRegionInfo, HRegionInfo, boolean, User) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to merge regions using admin protocol.
mergeRegions(RpcController, AdminProtos.MergeRegionsRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Merge regions on the region server.
mergeScan(ClientProtos.Scan) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .hbase.pb.Scan scan = 1;
message - Variable in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
message - Variable in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
message - Variable in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
message - Variable in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
message - Variable in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
MessageCodec - Class in org.apache.hadoop.hbase.codec
Codec that just writes out Cell as a protobuf Cell Message.
MessageCodec() - Constructor for class org.apache.hadoop.hbase.codec.MessageCodec
 
MessageModeScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.top
The presentation logic for the message mode.
MessageModeScreenPresenter(MessageModeScreenView, String, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenPresenter
 
MessageModeScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.top
The message mode in the top screen.
MessageModeScreenView(Screen, Terminal, int, String, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
 
meta - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
META_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
A KeyValue.KVComparator for hbase:meta catalog table KeyValues.
META_FAMILY_BYTES - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
 
META_QUALIFIER_BYTES - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
 
META_REPLICA_ID_DELIMITER - Static variable in class org.apache.hadoop.hbase.master.RegionStateStore
The delimiter for meta columns for replicaIds > 0
META_REPLICA_ID_DELIMITER - Static variable in class org.apache.hadoop.hbase.MetaTableAccessor
The delimiter for meta columns for replicaIds > 0
META_REPLICAS_NUM - Static variable in class org.apache.hadoop.hbase.HConstants
 
META_ROW_DELIMITER - Static variable in class org.apache.hadoop.hbase.HConstants
delimiter used between portions of a region name
META_SPLIT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
 
META_SPLIT_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
 
META_SPLIT_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
 
META_SPLIT_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
 
META_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
For upgrades of 0.94 to 0.96
META_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
The hbase:meta table's name.
META_TABLEDESC - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Use TableDescriptors#get(TableName.META_TABLE_NAME) or HBaseAdmin#getTableDescriptor(TableName.META_TABLE_NAME) instead.
META_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
The current version of the meta table.
META_VERSION_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The meta table version column qualifier.
META_WAL_PROVIDER_ID - Static variable in class org.apache.hadoop.hbase.wal.DefaultWALProvider
The hbase:meta region's WAL filename extension
META_ZNODE_PREFIX - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
metaBlockIndexReader - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Meta block index reader -- always single level
MetaCache - Class in org.apache.hadoop.hbase.client
A cache implementation for region locations from meta.
MetaCache(MetricsConnection) - Constructor for class org.apache.hadoop.hbase.client.MetaCache
 
metaCacheHits - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
metaCacheMisses - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
metaCacheNumClearRegion - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
metaCacheNumClearServer - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
METADATA - Static variable in class org.apache.hadoop.hbase.HConstants
 
metaData - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Writables representing meta block data.
metadata - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
 
metaDataMap - Static variable in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
metaDataMap - Static variable in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
metaDataMap - Static variable in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.TCell
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift.generated.TScan
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
metaDataMap - Static variable in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
metaDataMap - Static variable in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
METAFAMILY - Static variable in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
metaLocation - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
MetaMigrationConvertingToPB - Class in org.apache.hadoop.hbase
Deprecated.
will be removed for the major release after 0.96.
MetaMigrationConvertingToPB() - Constructor for class org.apache.hadoop.hbase.MetaMigrationConvertingToPB
Deprecated.
 
MetaMutationAnnotation - Annotation Type in org.apache.hadoop.hbase
The field or the parameter to which this annotation can be applied only when it holds mutations for hbase:meta table.
metaNames - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Meta block names.
metaRegionExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Checks if meta region exists
METAROW - Static variable in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
metaScan(Connection, MetaScanner.MetaScannerVisitor) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Scans the meta table and calls a visitor on each RowResult and uses a empty start row value as table name.
metaScan(Connection, MetaScanner.MetaScannerVisitor, TableName) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Scans the meta table and calls a visitor on each RowResult.
metaScan(Connection, MetaScanner.MetaScannerVisitor, TableName, byte[], int) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Scans the meta table and calls a visitor on each RowResult.
MetaScanner - Class in org.apache.hadoop.hbase.client
Scanner class that contains the hbase:meta table scanning logic.
MetaScanner() - Constructor for class org.apache.hadoop.hbase.client.MetaScanner
 
MetaScanner.DefaultMetaScannerVisitor - Class in org.apache.hadoop.hbase.client
A MetaScannerVisitor that skips offline regions and split parents
MetaScanner.DefaultMetaScannerVisitor() - Constructor for class org.apache.hadoop.hbase.client.MetaScanner.DefaultMetaScannerVisitor
 
MetaScanner.MetaScannerVisitor - Interface in org.apache.hadoop.hbase.client
Visitor class called to process each row of the hbase:meta table
MetaScanner.MetaScannerVisitorBase - Class in org.apache.hadoop.hbase.client
 
MetaScanner.MetaScannerVisitorBase() - Constructor for class org.apache.hadoop.hbase.client.MetaScanner.MetaScannerVisitorBase
 
MetaScanner.TableMetaScannerVisitor - Class in org.apache.hadoop.hbase.client
A MetaScannerVisitor for a table.
MetaScanner.TableMetaScannerVisitor(TableName) - Constructor for class org.apache.hadoop.hbase.client.MetaScanner.TableMetaScannerVisitor
 
MetaTableAccessor - Class in org.apache.hadoop.hbase
Read/write operations on region and assignment information store in hbase:meta.
MetaTableAccessor() - Constructor for class org.apache.hadoop.hbase.MetaTableAccessor
 
MetaTableAccessor.Visitor - Interface in org.apache.hadoop.hbase
Implementations 'visit' a catalog table row.
metaTableDescriptor(Configuration) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
 
metaTableLocator - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
MetaTableLocator - Class in org.apache.hadoop.hbase.zookeeper
Utility class to perform operation (get/wait for/verify/set/delete) on znode in ZooKeeper which keeps hbase:meta region server location.
MetaTableLocator() - Constructor for class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
MetaTableMetrics - Class in org.apache.hadoop.hbase.coprocessor
A coprocessor that collects metrics from meta table.
MetaTableMetrics() - Constructor for class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
 
MetaUtils - Class in org.apache.hadoop.hbase.util
Contains utility methods for manipulating HBase meta tables.
MetaUtils() - Constructor for class org.apache.hadoop.hbase.util.MetaUtils
Default constructor
MetaUtils(Configuration) - Constructor for class org.apache.hadoop.hbase.util.MetaUtils
 
meter(String) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
Meter - Interface in org.apache.hadoop.hbase.metrics
A metric which measure the rate at which some operation is invoked.
meter(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
Get or construct a Meter used to measure durations and report distributions (a combination of a Timer and a Histogram.
Methods - Class in org.apache.hadoop.hbase.util
 
Methods() - Constructor for class org.apache.hadoop.hbase.util.Methods
 
Metric - Interface in org.apache.hadoop.hbase.metrics
Parent interface for all metrics.
MetricHistogram - Interface in org.apache.hadoop.metrics2
Metrics Histogram interface.
MetricQuantile - Class in org.apache.hadoop.metrics2.util
Specifies a quantile (with error bounds) to be watched by a MetricSampleQuantiles object.
MetricQuantile(double, double) - Constructor for class org.apache.hadoop.metrics2.util.MetricQuantile
 
MetricRegistries - Class in org.apache.hadoop.hbase.metrics
MetricRegistries is collection of MetricRegistry's.
MetricRegistries() - Constructor for class org.apache.hadoop.hbase.metrics.MetricRegistries
 
MetricRegistriesImpl - Class in org.apache.hadoop.hbase.metrics.impl
Implementation of MetricRegistries that does ref-counting.
MetricRegistriesImpl() - Constructor for class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
 
MetricRegistriesImpl(MetricRegistryFactory) - Constructor for class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
 
MetricRegistriesLoader - Class in org.apache.hadoop.hbase.metrics
 
MetricRegistriesLoader() - Constructor for class org.apache.hadoop.hbase.metrics.MetricRegistriesLoader
 
MetricRegistry - Interface in org.apache.hadoop.hbase.metrics
General purpose factory for creating various metrics.
MetricRegistryFactory - Interface in org.apache.hadoop.hbase.metrics
A Factory for creating MetricRegistries.
MetricRegistryFactoryImpl - Class in org.apache.hadoop.hbase.metrics.impl
 
MetricRegistryFactoryImpl() - Constructor for class org.apache.hadoop.hbase.metrics.impl.MetricRegistryFactoryImpl
 
MetricRegistryImpl - Class in org.apache.hadoop.hbase.metrics.impl
Custom implementation of MetricRegistry.
MetricRegistryImpl(MetricRegistryInfo) - Constructor for class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
MetricRegistryInfo - Class in org.apache.hadoop.hbase.metrics
HBase Metrics are grouped in different MetricRegistry'ies.
MetricRegistryInfo(String, String, String, String, boolean) - Constructor for class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
 
metrics - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
metrics - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
The name of the metrics context that metrics will be under.
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
The context metrics will be under.
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
The context metrics will be under.
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
The context metrics will be under.
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
The context metrics will be under.
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
The context metrics will be under.
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
The context metrics will be under.
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
The name of the metrics context that metrics will be under.
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
The name of the metrics context that metrics will be under.
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
The name of the metrics context that metrics will be under.
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
The name of the metrics context that metrics will be under.
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySource
The name of the metrics context that metrics will be under.
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
The name of the metrics context that metrics will be under.
METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSource
The name of the metrics context that metrics will be under.
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
Description
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
Description
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
Description
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
Description
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
Description
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
Description
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
Description
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
Description
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Description
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
Description
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
Description
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySource
Description
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Description
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSource
A description.
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
 
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
The name of the metrics context that metrics will be under in jmx
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
The name of the metrics context that metrics will be under in jmx
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
The name of the metrics context that metrics will be under in jmx
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
The name of the metrics context that metrics will be under in jmx
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
The name of the metrics context that metrics will be under in jmx
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
The name of the metrics context that metrics will be under in jmx
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
The name of the metrics context that metrics will be under in jmx
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
The name of the metrics context that metrics will be under in jmx
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
The name of the metrics context that metrics will be under in jmx
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
The name of the metrics context that metrics will be under in jmx
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
The name of the metrics context that metrics will be under in jmx
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySource
The name of the metrics context that metrics will be under in jmx
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
The name of the metrics context that metrics will be under in jmx
METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSource
The name of the metrics context that metrics will be under.
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySource
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSource
The name of the metrics
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
 
METRICS_RIT_STUCK_WARNING_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
Region in Transition metrics threshold time
metricsAdapter - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
The adapter from hbase-metrics module to metrics2.
MetricSampleQuantiles - Class in org.apache.hadoop.metrics2.util
Implementation of the Cormode, Korn, Muthukrishnan, and Srivastava algorithm for streaming calculation of targeted high-percentile epsilon-approximate quantiles.
MetricSampleQuantiles(MetricQuantile[]) - Constructor for class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
 
MetricsAssignmentManager - Class in org.apache.hadoop.hbase.master
 
MetricsAssignmentManager() - Constructor for class org.apache.hadoop.hbase.master.MetricsAssignmentManager
 
MetricsAssignmentManagerSource - Interface in org.apache.hadoop.hbase.master
 
MetricsAssignmentManagerSourceImpl - Class in org.apache.hadoop.hbase.master
 
MetricsAssignmentManagerSourceImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
 
MetricsAssignmentManagerSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
 
metricsBalancer - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
MetricsBalancer - Class in org.apache.hadoop.hbase.master.balancer
Faced for exposing metrics about the balancer.
MetricsBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
 
MetricsBalancerSource - Interface in org.apache.hadoop.hbase.master.balancer
 
MetricsBalancerSourceImpl - Class in org.apache.hadoop.hbase.master.balancer
 
MetricsBalancerSourceImpl() - Constructor for class org.apache.hadoop.hbase.master.balancer.MetricsBalancerSourceImpl
 
MetricsBalancerSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.master.balancer.MetricsBalancerSourceImpl
 
MetricsConnection - Class in org.apache.hadoop.hbase.client
This class is for maintaining the various connection statistics and publishing them through the metrics interfaces.
MetricsConnection(ConnectionManager.HConnectionImplementation) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection
 
MetricsConnection.CallStats - Class in org.apache.hadoop.hbase.client
A container class for collecting details about the RPC call as it percolates.
MetricsConnection.CallStats() - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
MetricsConnection.CallTracker - Class in org.apache.hadoop.hbase.client
 
MetricsConnection.RegionStats - Class in org.apache.hadoop.hbase.client
 
MetricsConnection.RegionStats(MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.RegionStats
 
MetricsConnection.RunnerStats - Class in org.apache.hadoop.hbase.client
 
MetricsConnection.RunnerStats(MetricsRegistry) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
metricsContext - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
metricsContext - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
 
MetricsCoprocessor - Class in org.apache.hadoop.hbase.coprocessor
Utility class for tracking metrics for various types of coprocessors.
MetricsCoprocessor() - Constructor for class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
metricsDescription - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
metricsDescription - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
 
MetricsEditsReplaySource - Interface in org.apache.hadoop.hbase.regionserver.wal
Interface of the source that will export metrics about log replay statistics when recovering a region server in distributedLogReplay mode
MetricsEditsReplaySourceImpl - Class in org.apache.hadoop.hbase.regionserver.wal
Hadoop1 implementation of MetricsMasterSource.
MetricsEditsReplaySourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySourceImpl
 
MetricsEditsReplaySourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySourceImpl
 
MetricSet - Interface in org.apache.hadoop.hbase.metrics
A set of named metrics.
MetricsExecutor - Interface in org.apache.hadoop.metrics2
ScheduledExecutorService for metrics.
MetricsExecutorImpl - Class in org.apache.hadoop.metrics2.lib
Class to handle the ScheduledExecutorServiceScheduledExecutorService used by MetricsRegionAggregateSourceImpl, and JmxCacheBuster
MetricsExecutorImpl() - Constructor for class org.apache.hadoop.metrics2.lib.MetricsExecutorImpl
 
MetricsHBaseServer - Class in org.apache.hadoop.hbase.ipc
 
MetricsHBaseServer(String, MetricsHBaseServerWrapper) - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
 
MetricsHBaseServerSource - Interface in org.apache.hadoop.hbase.ipc
 
MetricsHBaseServerSourceFactory - Class in org.apache.hadoop.hbase.ipc
 
MetricsHBaseServerSourceFactory() - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory
 
MetricsHBaseServerSourceFactoryImpl - Class in org.apache.hadoop.hbase.ipc
 
MetricsHBaseServerSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl
 
MetricsHBaseServerSourceImpl - Class in org.apache.hadoop.hbase.ipc
 
MetricsHBaseServerSourceImpl(String, String, String, String, MetricsHBaseServerWrapper) - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
MetricsHBaseServerWrapper - Interface in org.apache.hadoop.hbase.ipc
 
MetricsHBaseServerWrapperImpl - Class in org.apache.hadoop.hbase.ipc
 
MetricsIO - Class in org.apache.hadoop.hbase.io
 
MetricsIO(MetricsIOWrapper) - Constructor for class org.apache.hadoop.hbase.io.MetricsIO
 
MetricsIOSource - Interface in org.apache.hadoop.hbase.io
 
MetricsIOSourceImpl - Class in org.apache.hadoop.hbase.io
 
MetricsIOSourceImpl(MetricsIOWrapper) - Constructor for class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
 
MetricsIOSourceImpl(String, String, String, String, MetricsIOWrapper) - Constructor for class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
 
MetricsIOWrapper - Interface in org.apache.hadoop.hbase.io
 
MetricsIOWrapperImpl - Class in org.apache.hadoop.hbase.io
 
MetricsIOWrapperImpl() - Constructor for class org.apache.hadoop.hbase.io.MetricsIOWrapperImpl
 
metricsJmxContext - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
metricsJmxContext - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
 
MetricsMaster - Class in org.apache.hadoop.hbase.master
This class is for maintaining the various master statistics and publishing them through the metrics interfaces.
MetricsMaster(MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMaster
 
MetricsMasterFileSystem - Class in org.apache.hadoop.hbase.master
 
MetricsMasterFileSystem() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
 
MetricsMasterFileSystemSource - Interface in org.apache.hadoop.hbase.master
 
MetricsMasterFilesystemSourceImpl - Class in org.apache.hadoop.hbase.master
 
MetricsMasterFilesystemSourceImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
 
MetricsMasterFilesystemSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
 
MetricsMasterProcSource - Interface in org.apache.hadoop.hbase.master
Interface that classes that expose metrics about the master will implement.
MetricsMasterProcSourceFactory - Interface in org.apache.hadoop.hbase.master
Interface of a factory to create MetricsMasterSource when given a MetricsMasterWrapper
MetricsMasterProcSourceFactoryImpl - Class in org.apache.hadoop.hbase.master
Factory to create MetricsMasterProcSource when given a MetricsMasterWrapper
MetricsMasterProcSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactoryImpl
 
MetricsMasterProcSourceImpl - Class in org.apache.hadoop.hbase.master
Hadoop2 implementation of MetricsMasterSource.
MetricsMasterProcSourceImpl(MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
 
MetricsMasterProcSourceImpl(String, String, String, String, MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
 
MetricsMasterSource - Interface in org.apache.hadoop.hbase.master
Interface that classes that expose metrics about the master will implement.
MetricsMasterSourceFactory - Interface in org.apache.hadoop.hbase.master
Interface of a factory to create MetricsMasterSource when given a MetricsMasterWrapper
MetricsMasterSourceFactoryImpl - Class in org.apache.hadoop.hbase.master
Factory to create MetricsMasterSource when given a MetricsMasterWrapper
MetricsMasterSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl
 
MetricsMasterSourceImpl - Class in org.apache.hadoop.hbase.master
Hadoop2 implementation of MetricsMasterSource.
MetricsMasterSourceImpl(MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
 
MetricsMasterSourceImpl(String, String, String, String, MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
 
MetricsMasterWrapper - Interface in org.apache.hadoop.hbase.master
This is the interface that will expose information to hadoop1/hadoop2 implementations of the MetricsMasterSource.
MetricsMasterWrapperImpl - Class in org.apache.hadoop.hbase.master
Impl for exposing HMaster Information through JMX
MetricsMasterWrapperImpl(HMaster) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
 
metricsName - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
metricsName - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
 
MetricsRegion - Class in org.apache.hadoop.hbase.regionserver
This is the glue between the HRegion and whatever hadoop shim layer is loaded (hbase-hadoop1-compat or hbase-hadoop2-compat).
MetricsRegion(MetricsRegionWrapper) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
MetricsRegionAggregateSource - Interface in org.apache.hadoop.hbase.regionserver
This interface will be implemented by a MetricsSource that will export metrics from multiple regions into the hadoop metrics system.
MetricsRegionAggregateSourceImpl - Class in org.apache.hadoop.hbase.regionserver
 
MetricsRegionAggregateSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
 
MetricsRegionAggregateSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
 
MetricsRegionServer - Class in org.apache.hadoop.hbase.regionserver
This class is for maintaining the various regionserver statistics and publishing them through the metrics interfaces.
MetricsRegionServer(MetricsRegionServerWrapper, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
MetricsRegionServerSource - Interface in org.apache.hadoop.hbase.regionserver
Interface for classes that expose metrics about the regionserver.
MetricsRegionServerSourceFactory - Interface in org.apache.hadoop.hbase.regionserver
Interface of a factory to create Metrics Sources used inside of regionservers.
MetricsRegionServerSourceFactoryImpl - Class in org.apache.hadoop.hbase.regionserver
Factory to create MetricsRegionServerSource when given a MetricsRegionServerWrapper
MetricsRegionServerSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
 
MetricsRegionServerSourceFactoryImpl.FactoryStorage - Enum in org.apache.hadoop.hbase.regionserver
 
MetricsRegionServerSourceImpl - Class in org.apache.hadoop.hbase.regionserver
Hadoop2 implementation of MetricsRegionServerSource.
MetricsRegionServerSourceImpl(MetricsRegionServerWrapper) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
MetricsRegionServerSourceImpl(String, String, String, String, MetricsRegionServerWrapper) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
MetricsRegionServerWrapper - Interface in org.apache.hadoop.hbase.regionserver
This is the interface that will expose RegionServer information to hadoop1/hadoop2 implementations of the MetricsRegionServerSource.
MetricsRegionSource - Interface in org.apache.hadoop.hbase.regionserver
This interface will be implemented to allow single regions to push metrics into MetricsRegionAggregateSource that will in turn push data to the Hadoop metrics system.
MetricsRegionSourceImpl - Class in org.apache.hadoop.hbase.regionserver
 
MetricsRegionSourceImpl(MetricsRegionWrapper, MetricsRegionAggregateSourceImpl) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
MetricsRegionWrapper - Interface in org.apache.hadoop.hbase.regionserver
Interface of class that will wrap an HRegion and export numbers so they can be used in MetricsRegionSource
MetricsRegionWrapperImpl - Class in org.apache.hadoop.hbase.regionserver
 
MetricsRegionWrapperImpl(HRegion) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable - Class in org.apache.hadoop.hbase.regionserver
 
MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable
 
metricsRegistry - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
Deprecated.
Use hbase-metrics/hbase-metrics-api module interfaces for new metrics. Defining BaseSources for new metric groups (WAL, RPC, etc) is not needed anymore, however, for existing BaseSource implemetnations, please use the field named "registry" which is a MetricRegistry instance together with the HBaseMetrics2HadoopMetricsAdapter.
MetricsReplicationGlobalSourceSource - Class in org.apache.hadoop.hbase.replication.regionserver
 
MetricsReplicationGlobalSourceSource(MetricsReplicationSourceImpl) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
MetricsReplicationSinkSource - Interface in org.apache.hadoop.hbase.replication.regionserver
 
MetricsReplicationSinkSourceImpl - Class in org.apache.hadoop.hbase.replication.regionserver
 
MetricsReplicationSinkSourceImpl(MetricsReplicationSourceImpl) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
 
MetricsReplicationSource - Interface in org.apache.hadoop.hbase.replication.regionserver
Provides access to gauges and counters.
MetricsReplicationSourceFactory - Interface in org.apache.hadoop.hbase.replication.regionserver
 
MetricsReplicationSourceFactoryImpl - Class in org.apache.hadoop.hbase.replication.regionserver
 
MetricsReplicationSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl
 
MetricsReplicationSourceImpl - Class in org.apache.hadoop.hbase.replication.regionserver
Hadoop2 implementation of MetricsReplicationSource.
MetricsReplicationSourceImpl() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceImpl
 
MetricsReplicationSourceSource - Interface in org.apache.hadoop.hbase.replication.regionserver
 
MetricsReplicationSourceSourceImpl - Class in org.apache.hadoop.hbase.replication.regionserver
 
MetricsReplicationSourceSourceImpl(MetricsReplicationSourceImpl, String) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
MetricsREST - Class in org.apache.hadoop.hbase.rest
 
MetricsREST() - Constructor for class org.apache.hadoop.hbase.rest.MetricsREST
 
MetricsRESTSource - Interface in org.apache.hadoop.hbase.rest
Interface of the Metrics Source that will export data to Hadoop's Metrics2 system.
MetricsRESTSourceImpl - Class in org.apache.hadoop.hbase.rest
Hadoop Two implementation of a metrics2 source that will export metrics from the Rest server to the hadoop metrics2 subsystem.
MetricsRESTSourceImpl() - Constructor for class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
MetricsRESTSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
MetricsSink - Class in org.apache.hadoop.hbase.replication.regionserver
This class is for maintaining the various replication statistics for a sink and publishing them through the metrics interfaces.
MetricsSink() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
 
MetricsSnapshot - Class in org.apache.hadoop.hbase.master
 
MetricsSnapshot() - Constructor for class org.apache.hadoop.hbase.master.MetricsSnapshot
 
metricsSnapshot - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
MetricsSnapshotSource - Interface in org.apache.hadoop.hbase.master
 
MetricsSnapshotSourceImpl - Class in org.apache.hadoop.hbase.master
 
MetricsSnapshotSourceImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
 
MetricsSnapshotSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
 
MetricsSource - Class in org.apache.hadoop.hbase.replication.regionserver
This class is for maintaining the various replication statistics for a source and publishing them through the metrics interfaces.
MetricsSource(String) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Constructor used to register the metrics
MetricsSource(String, MetricsReplicationSourceSource, MetricsReplicationSourceSource, Map<String, MetricsReplicationSourceSource>) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Constructor for injecting custom (or test) MetricsReplicationSourceSources
MetricsStochasticBalancer - Class in org.apache.hadoop.hbase.master.balancer
This metrics balancer uses extended source for stochastic load balancer to report its related metrics to JMX.
MetricsStochasticBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
 
MetricsStochasticBalancerSource - Interface in org.apache.hadoop.hbase.master.balancer
This interface extends the basic metrics balancer source to add a function to report metrics that related to stochastic load balancer.
MetricsStochasticBalancerSourceImpl - Class in org.apache.hadoop.hbase.master.balancer
 
MetricsStochasticBalancerSourceImpl() - Constructor for class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSourceImpl
 
MetricsTable - Class in org.apache.hadoop.hbase.regionserver
 
MetricsTable(MetricsTableWrapperAggregate) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTable
 
MetricsTableAggregateSource - Interface in org.apache.hadoop.hbase.regionserver
This interface will be implemented by a MetricsSource that will export metrics from multiple regions of a table into the hadoop metrics system.
MetricsTableAggregateSourceImpl - Class in org.apache.hadoop.hbase.regionserver
 
MetricsTableAggregateSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
 
MetricsTableAggregateSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
 
MetricsTableLatencies - Interface in org.apache.hadoop.hbase.regionserver
Latency metrics for a specific table in a RegionServer.
MetricsTableLatenciesImpl - Class in org.apache.hadoop.hbase.regionserver
Implementation of MetricsTableLatencies to track latencies for one table in a RegionServer.
MetricsTableLatenciesImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
MetricsTableLatenciesImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
MetricsTableLatenciesImpl.TableHistograms - Class in org.apache.hadoop.hbase.regionserver
 
MetricsTableQueryMeter - Interface in org.apache.hadoop.hbase.regionserver
Query Per Second for each table in a RegionServer.
MetricsTableQueryMeterImpl - Class in org.apache.hadoop.hbase.regionserver
Implementation of MetricsTableQueryMeter to track query per second for each table in a RegionServer.
MetricsTableQueryMeterImpl(MetricRegistry) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableQueryMeterImpl
 
MetricsTableSource - Interface in org.apache.hadoop.hbase.regionserver
This interface will be implemented to allow region server to push table metrics into MetricsRegionAggregateSource that will in turn push data to the Hadoop metrics system.
MetricsTableSourceImpl - Class in org.apache.hadoop.hbase.regionserver
 
MetricsTableSourceImpl(String, MetricsTableAggregateSourceImpl, MetricsTableWrapperAggregate) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
MetricsTableWrapperAggregate - Interface in org.apache.hadoop.hbase.regionserver
Interface of class that will wrap a MetricsTableSource and export numbers so they can be used in MetricsTableSource
MetricsTableWrapperAggregateImpl - Class in org.apache.hadoop.hbase.regionserver
 
MetricsTableWrapperAggregateImpl(HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
 
MetricsTableWrapperAggregateImpl.TableMetricsWrapperRunnable - Class in org.apache.hadoop.hbase.regionserver
 
MetricsTableWrapperAggregateImpl.TableMetricsWrapperRunnable() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.TableMetricsWrapperRunnable
 
MetricsThriftServerSource - Interface in org.apache.hadoop.hbase.thrift
Interface of a class that will export metrics about Thrift to hadoop's metrics2.
MetricsThriftServerSourceFactory - Interface in org.apache.hadoop.hbase.thrift
Factory that will be used to create metrics sources for the two diffent types of thrift servers.
MetricsThriftServerSourceFactoryImpl - Class in org.apache.hadoop.hbase.thrift
Class used to create metrics sources for Thrift and Thrift2 servers.
MetricsThriftServerSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl
 
MetricsThriftServerSourceImpl - Class in org.apache.hadoop.hbase.thrift
Hadoop 2 version of MetricsThriftServerSourceMetricsThriftServerSource Implements BaseSource through BaseSourceImpl, following the pattern
MetricsThriftServerSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
MetricsWAL - Class in org.apache.hadoop.hbase.regionserver.wal
Class used to push numbers about the WAL into the metrics subsystem.
MetricsWAL() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
 
MetricsWALEditsReplay - Class in org.apache.hadoop.hbase.regionserver.wal
Class used to push numbers about WAL edits replay into the metrics subsystem.
MetricsWALEditsReplay() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsWALEditsReplay
 
MetricsWALSource - Interface in org.apache.hadoop.hbase.regionserver.wal
Interface of the source that will export metrics about the region server's WAL.
MetricsWALSourceImpl - Class in org.apache.hadoop.hbase.regionserver.wal
Class that transitions metrics from MetricsWAL into the metrics subsystem.
MetricsWALSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
MetricsWALSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
midkey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
 
midkey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
midkey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
An approximation to the HFile's mid-key.
midkey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
midkey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
migrateACL() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
 
migrateDotDirs() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
Rename all the dot dirs -- .data, .archive, etc.
migrateFSTableDescriptorsIfNecessary(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptorMigrationToSubdir
Deprecated.
 
migrateMeta() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
 
migrateSnapshots() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
 
migrateTables() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
Migrate all tables into respective namespaces, either default or system.
MIGRATION_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Any artifacts left from migration can be moved here
MILLIS_BETWEEN_NEXTS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
MIMETYPE_BINARY - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
MIMETYPE_HTML - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
MIMETYPE_JSON - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
MIMETYPE_PROTOBUF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
MIMETYPE_PROTOBUF_IETF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
MIMETYPE_TEXT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
MIMETYPE_XML - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
min(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the minimum value of a column for a given column family for the given range.
min(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the minimum value of a column for a given column family for the given range.
min - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
MIN_CORE_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.ChoreService
The minimum number of threads in the core pool of the underlying ScheduledThreadPoolExecutor
MIN_COST_NEED_BALANCE_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
MIN_FILES_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
The minimum number of files to compact within a stripe; same as for regular compaction.
MIN_FILES_L0_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
The minimum number of files to compact when compacting L0; same as minFiles for regular compaction.
MIN_FORMAT_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Minimum supported HFile format version
MIN_FORMAT_VERSION_WITH_TAGS - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Minimum HFile format version with support for persisting cell tags
MIN_INDEX_NUM_ENTRIES_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
Minimum number of entries in a single index block.
MIN_KEEP_SEQID_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
At least to keep MVCC values in hfiles for 5 days
MIN_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
MIN_NUM_HFILE_PATH_LEVELS - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
We assume that HFile path ends with ROOT_DIR/TABLE_NAME/REGION_NAME/CF_NAME/HFILE, so it has at least this many levels of nesting.
MIN_SERVER_BALANCE - Static variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
MIN_STORE_FILE_AGE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MIN_STORE_FILE_AGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
MIN_WAIT_TIME - Static variable in class org.apache.hadoop.hbase.regionserver.Leases
 
MIN_WORKER_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
The "core size" of the thread pool.
minColumn - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
minColumnInclusive - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
MiniBatchOperationInProgress<T> - Class in org.apache.hadoop.hbase.regionserver
Wraps together the mutations which are applied as a batch to the region and their operation status and WALEdits.
MiniBatchOperationInProgress(T[], OperationStatus[], WALEdit[], int, int) - Constructor for class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
 
minIdleTimeBeforeClose - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
MiniZooKeeperCluster - Class in org.apache.hadoop.hbase.zookeeper
TODO: Most of the code in this class is ripped from ZooKeeper tests.
MiniZooKeeperCluster() - Constructor for class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
MiniZooKeeperCluster(Configuration) - Constructor for class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
minMvccVersion - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
MINOR_COMPACTION_DROP_CACHE - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
MINOR_VERSION - Static variable in exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
 
MINOR_VERSION_NO_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
In HFile V2 minor version that does not support checksums
MINOR_VERSION_WITH_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
Minor versions in HFile V2 starting with this number have hbase checksums
MinorCompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
Query matcher for minor compaction.
MinorCompactionScanQueryMatcher(ScanInfo, DeleteTracker, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.MinorCompactionScanQueryMatcher
 
minSeqIdToKeep - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
Min SeqId to keep during a major compaction
minStamp - Variable in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
minTimestamp - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
MINUS_SIGN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII for Minus Sign
MINUTE_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
 
minVersions - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
MISC_INVOATION_COUNT - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
 
miss(boolean, boolean, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
Mode - Enum in org.apache.hadoop.hbase.hbtop.mode
Represents a display mode in the top screen.
ModeScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.mode
The presentation logic for the mode screen.
ModeScreenPresenter(ModeScreenView, Mode, ModeScreenPresenter.ResultListener, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
 
ModeScreenPresenter.ResultListener - Interface in org.apache.hadoop.hbase.hbtop.screen.mode
 
ModeScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.mode
The screen where we can choose the Mode in the top screen.
ModeScreenView(Screen, Terminal, Mode, ModeScreenPresenter.ResultListener, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
 
modifyColumn(TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing column family on a table.
modifyColumn(String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing column family on a table.
modifyColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing column family on a table.
modifyColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing column family on a table.
modifyColumn(TableName, HColumnDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
modifyColumn(RpcController, MasterProtos.ModifyColumnRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
modifyColumn(TableName, HColumnDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Modify the column descriptor of an existing column in an existing table
ModifyColumnFamilyProcedure - Class in org.apache.hadoop.hbase.master.procedure
The procedure to modify a column family from an existing table.
ModifyColumnFamilyProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
ModifyColumnFamilyProcedure(MasterProcedureEnv, TableName, HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
modifyFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
modifyFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Modifies the existing column family.
modifyNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing namespace
modifyNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing namespace
modifyNamespace(NamespaceDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
modifyNamespace(RpcController, MasterProtos.ModifyNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
modifyNamespace(NamespaceDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Modify an existing namespace
ModifyNamespaceProcedure - Class in org.apache.hadoop.hbase.master.procedure
The procedure to add a namespace to an existing table.
ModifyNamespaceProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
ModifyNamespaceProcedure(MasterProcedureEnv, NamespaceDescriptor) - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
ModifyRegionUtils - Class in org.apache.hadoop.hbase.util
Utility methods for interacting with the regions.
ModifyRegionUtils.RegionEditTask - Interface in org.apache.hadoop.hbase.util
 
ModifyRegionUtils.RegionFillTask - Interface in org.apache.hadoop.hbase.util
 
modifyTable(TableName, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Modify an existing table, more IRB friendly version.
modifyTable(TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Modify an existing table, more IRB friendly version.
modifyTable(byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
modifyTable(String, HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
modifyTable(TableName, HTableDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
modifyTable(RpcController, MasterProtos.ModifyTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
modifyTable(TableName, HTableDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Modify the descriptor of an existing table
ModifyTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
 
ModifyTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
ModifyTableProcedure(MasterProcedureEnv, HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
monitor - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
monitor - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
monitor to check for errors
MONITOR_INTERVAL_KEY - Static variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
MonitoredRPCHandler - Interface in org.apache.hadoop.hbase.monitoring
A MonitoredTask implementation optimized for use with RPC Handlers handling frequent, short duration tasks.
MonitoredRPCHandlerImpl - Class in org.apache.hadoop.hbase.monitoring
A MonitoredTask implementation designed for use with RPC Handlers handling frequent, short duration tasks.
MonitoredRPCHandlerImpl() - Constructor for class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
 
MonitoredTask - Interface in org.apache.hadoop.hbase.monitoring
 
MonitoredTask.State - Enum in org.apache.hadoop.hbase.monitoring
 
MonitoredTask.StatusJournalEntry - Interface in org.apache.hadoop.hbase.monitoring
 
moreRowsMayExistAfter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
moreRowsMayExistAfter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.LegacyScanQueryMatcher
Deprecated.
 
moreRowsMayExistAfter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
moreRowsMayExistAfter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
moreRowsMayExistsAfter(int) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
move(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Move the region r to dest.
move(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Move the region r to dest.
move(byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
moveAsideBadEditsFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
Move aside a bad edits file.
moveBufferToStream(OutputStream, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copy the data to the output stream and update position in buffer.
moveChildrenToDifferentParent(TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
moveCursor(int, int) - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
 
movedRegionCleanerPeriod() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
movedRegionException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
movedRegionException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
movedRegions - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
moveFromOnlineToDeadServers(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
moveRegion(RpcController, MasterProtos.MoveRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
moveServers(Set<Address>, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Move given set of servers to the specified target RegionServer group.
moveServers(RpcController, RSGroupAdminProtos.MoveServersRequest, RpcCallback<RSGroupAdminProtos.MoveServersResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
moveServers(Set<Address>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
moveServers(Set<Address>, String, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Move servers to a new group.
moveServers(Set<Address>, String, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
moveServersAndTables(Set<Address>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Move given set of servers and tables to the specified target RegionServer group.
moveServersAndTables(RpcController, RSGroupAdminProtos.MoveServersAndTablesRequest, RpcCallback<RSGroupAdminProtos.MoveServersAndTablesResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
moveServersAndTables(Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
moveServersAndTables(Set<Address>, Set<TableName>, String, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Move servers and tables to a new group.
moveServersAndTables(Set<Address>, Set<TableName>, String, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
moveTables(Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Move given set of tables to the specified target RegionServer group.
moveTables(RpcController, RSGroupAdminProtos.MoveTablesRequest, RpcCallback<RSGroupAdminProtos.MoveTablesResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
moveTables(Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
moveTables(Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Set the group membership of a set of tables
moveTables(Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
moveToNextRegion() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Close the previous scanner and create a new ScannerCallable for the next scanner.
mput - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
mutation for the put
msgInterval - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
MULITPLE_FAMILIES_POSSIBLE - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
multi(RpcController, ClientProtos.MultiRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Execute multiple actions on a table: get, mutate, and/or execCoprocessor
multi(Iterable<Op>) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
Run multiple operations in a transactional manner.
MultiAction<R> - Class in org.apache.hadoop.hbase.client
Container for Actions (i.e.
MultiAction() - Constructor for class org.apache.hadoop.hbase.client.MultiAction
 
MultiActionResultTooLarge - Exception in org.apache.hadoop.hbase
Exception thrown when the result needs to be chunked on the server side.
MultiActionResultTooLarge(String) - Constructor for exception org.apache.hadoop.hbase.MultiActionResultTooLarge
 
multiActionTooLargeException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
multiActionTooLargeException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
multiAp - Variable in class org.apache.hadoop.hbase.client.HTable
The Async process for batch
MultiHConnection - Class in org.apache.hadoop.hbase.util
Provides ability to create multiple HConnection instances and allows to process a batch of actions using HConnection.processBatchCallback()
MultiHConnection(Configuration, int) - Constructor for class org.apache.hadoop.hbase.util.MultiHConnection
Create multiple HConnection instances and initialize a thread pool executor
multiOrSequential(ZooKeeperWatcher, List<ZKUtil.ZKUtilOp>, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
If hbase.zookeeper.useMulti is true, use ZooKeeper's multi-update functionality.
multiple(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Create a byte array which is multiple given bytes
MultipleColumnPrefixFilter - Class in org.apache.hadoop.hbase.filter
This filter is used for selecting only those keys with columns that matches a particular prefix.
MultipleColumnPrefixFilter(byte[][]) - Constructor for class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
multiply(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
multiply(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
multiply(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
multiply(S, S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
MultiResponse - Class in org.apache.hadoop.hbase.client
A container for Result objects, grouped by regionName.
MultiResponse() - Constructor for class org.apache.hadoop.hbase.client.MultiResponse
 
MultiRowMutationEndpoint - Class in org.apache.hadoop.hbase.coprocessor
This class demonstrates how to implement atomic multi row transactions using HRegion.mutateRowsWithLocks(java.util.Collection, java.util.Collection) and Coprocessor endpoints.
MultiRowMutationEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
 
MultiRowRangeFilter - Class in org.apache.hadoop.hbase.filter
Filter to support scan multiple row key ranges.
MultiRowRangeFilter(List<MultiRowRangeFilter.RowRange>) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
MultiRowRangeFilter(byte[][]) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
Constructor for creating a MultiRowRangeFilter from multiple rowkey prefixes.
MultiRowRangeFilter.RowRange - Class in org.apache.hadoop.hbase.filter
 
MultiRowRangeFilter.RowRange() - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
MultiRowRangeFilter.RowRange(String, boolean, String, boolean) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
If the startRow is empty or null, set it to HConstants.EMPTY_BYTE_ARRAY, means begin at the start row of the table.
MultiRowRangeFilter.RowRange(byte[], boolean, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
MultiRowResource - Class in org.apache.hadoop.hbase.rest
 
MultiRowResource(TableResource, String, String) - Constructor for class org.apache.hadoop.hbase.rest.MultiRowResource
Constructor
MultiTableInputFormat - Class in org.apache.hadoop.hbase.mapreduce
Convert HBase tabular data from multiple scanners into a format that is consumable by Map/Reduce.
MultiTableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
 
MultiTableInputFormatBase - Class in org.apache.hadoop.hbase.mapreduce
MultiTableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
 
MultiTableOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
Hadoop output format that writes to one or more HBase tables.
MultiTableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
 
MultiTableOutputFormat.MultiTableRecordWriter - Class in org.apache.hadoop.hbase.mapreduce
Record writer for outputting to multiple HTables.
MultiTableOutputFormat.MultiTableRecordWriter(Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
 
MultiTableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapred
MultiTableSnapshotInputFormat generalizes .TableSnapshotInputFormat allowing a MapReduce job to run over one or more table snapshots, with one or more scans configured for each.
MultiTableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
 
MultiTableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapreduce
MultiTableSnapshotInputFormat generalizes TableSnapshotInputFormat allowing a MapReduce job to run over one or more table snapshots, with one or more scans configured for each.
MultiTableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
 
MultiTableSnapshotInputFormatImpl - Class in org.apache.hadoop.hbase.mapreduce
Shared implementation of mapreduce code over multiple table snapshots.
MultiTableSnapshotInputFormatImpl() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
 
MultiThreadedClientExample - Class in org.apache.hadoop.hbase.client.example
Example on how to use HBase's Connection and Table in a multi-threaded environment.
MultiThreadedClientExample() - Constructor for class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample
 
MultiThreadedClientExample.ReadExampleCallable - Class in org.apache.hadoop.hbase.client.example
Class to show how to scan some rows starting at a random location.
MultiThreadedClientExample.ReadExampleCallable(Connection, TableName) - Constructor for class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.ReadExampleCallable
 
MultiThreadedClientExample.SingleWriteExampleCallable - Class in org.apache.hadoop.hbase.client.example
Class to show how to send a single put.
MultiThreadedClientExample.SingleWriteExampleCallable(Connection, TableName) - Constructor for class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.SingleWriteExampleCallable
 
MultiThreadedClientExample.WriteExampleCallable - Class in org.apache.hadoop.hbase.client.example
Class that will show how to send batches of puts at the same time.
MultiThreadedClientExample.WriteExampleCallable(Connection, TableName) - Constructor for class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.WriteExampleCallable
 
MultithreadedTableMapper<K2,V2> - Class in org.apache.hadoop.hbase.mapreduce
Multithreaded implementation for @link org.apache.hbase.mapreduce.TableMapper
MultithreadedTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
 
multiTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
MultiVersionConcurrencyControl - Class in org.apache.hadoop.hbase.regionserver
Manages the read/write consistency.
MultiVersionConcurrencyControl() - Constructor for class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
 
MultiVersionConcurrencyControl(long) - Constructor for class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Construct and set read point.
MultiVersionConcurrencyControl.WriteEntry - Class in org.apache.hadoop.hbase.regionserver
Write number and whether write has completed given out at start of a write transaction.
MunkresAssignment - Class in org.apache.hadoop.hbase.util
Computes the optimal (minimal cost) assignment of jobs to workers (or other analogous) concepts given a cost matrix of each pair of job and worker, using the algorithm by James Munkres in "Algorithms for the Assignment and Transportation Problems", with additional optimizations as described by Jin Kue Wong in "A New Implementation of an Algorithm for the Optimal Assignment Problem: An Improved Version of Munkres' Algorithm".
MunkresAssignment(float[][]) - Constructor for class org.apache.hadoop.hbase.util.MunkresAssignment
Construct a new problem instance with the specified cost matrix.
MURMUR_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
Constant to denote MurmurHash.
MURMUR_HASH3 - Static variable in class org.apache.hadoop.hbase.util.Hash
Constant to denote MurmurHash3.
MurmurHash - Class in org.apache.hadoop.hbase.util
This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
MurmurHash() - Constructor for class org.apache.hadoop.hbase.util.MurmurHash
 
MurmurHash3 - Class in org.apache.hadoop.hbase.util
This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
MurmurHash3() - Constructor for class org.apache.hadoop.hbase.util.MurmurHash3
 
MutableFastCounter - Class in org.apache.hadoop.metrics2.lib
 
MutableFastCounter(MetricsInfo, long) - Constructor for class org.apache.hadoop.metrics2.lib.MutableFastCounter
 
MutableHistogram - Class in org.apache.hadoop.metrics2.lib
A histogram implementation that runs in constant space, and exports to hadoop2's metrics2 system.
MutableHistogram(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.lib.MutableHistogram
 
MutableHistogram(String, String) - Constructor for class org.apache.hadoop.metrics2.lib.MutableHistogram
 
MutableHistogram(String, String, long) - Constructor for class org.apache.hadoop.metrics2.lib.MutableHistogram
 
MutableRangeHistogram - Class in org.apache.hadoop.metrics2.lib
Extended histogram implementation with metric range counters.
MutableRangeHistogram(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
 
MutableRangeHistogram(String, String) - Constructor for class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
 
MutableRangeHistogram(String, String, long) - Constructor for class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
 
MutableSizeHistogram - Class in org.apache.hadoop.metrics2.lib
Extended histogram implementation with counters for metric size ranges.
MutableSizeHistogram(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
 
MutableSizeHistogram(String, String) - Constructor for class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
 
MutableSizeHistogram(String, String, long) - Constructor for class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
 
MutableTimeHistogram - Class in org.apache.hadoop.metrics2.lib
Extended histogram implementation with counters for metric time ranges.
MutableTimeHistogram(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
 
MutableTimeHistogram(String, String) - Constructor for class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
 
MutableTimeHistogram(String, String, long) - Constructor for class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
 
mutate(Mutation) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Sends a Mutation to the table.
mutate(List<? extends Mutation>) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Send some Mutations to the table.
mutate(Mutation) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
mutate(List<? extends Mutation>) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
mutate(RpcController, ClientProtos.MutateRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Mutate data in a table.
mutateMetaTable(Connection, List<Mutation>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Execute the passed mutations against hbase:meta table.
mutateRegions(Connection, List<HRegionInfo>, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds and Removes the specified regions from hbase:meta
mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
Performs multiple mutations atomically on a single row.
mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
Performs multiple mutations atomically on a single row.
mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Performs multiple mutations atomically on a single row.
mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
mutateRow(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
mutateRow(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
mutateRow(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
mutateRow(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Apply a series of mutations (updates/deletes) to a row in a single transaction.
mutateRow(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
mutateRow(ByteBuffer, TRowMutations, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
mutateRow(ByteBuffer, TRowMutations, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
mutateRow(ByteBuffer, TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
mutateRow(ByteBuffer, TRowMutations) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
mutateRow performs multiple mutations atomically on a single row.
mutateRow(ByteBuffer, TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
mutateRows(RpcController, MultiRowMutationProtos.MutateRowsRequest, RpcCallback<MultiRowMutationProtos.MutateRowsResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
 
mutateRows(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
mutateRows(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
mutateRows(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
mutateRows(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Apply a series of batches (each a series of mutations on a single row) in a single transaction.
mutateRows(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
mutateRowsTs(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
mutateRowsTs(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
mutateRowsTs(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
mutateRowsTs(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Apply a series of batches (each a series of mutations on a single row) in a single transaction.
mutateRowsTs(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
mutateRowsWithLocks(Collection<Mutation>, Collection<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Perform atomic mutations within the region w/o nonces.
mutateRowsWithLocks(Collection<Mutation>, Collection<byte[]>, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Perform atomic mutations within the region.
mutateRowsWithLocks(Collection<Mutation>, Collection<byte[]>, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Perform atomic mutations within the region.
mutateRowTs(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
mutateRowTs(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
mutateRowTs(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
mutateRowTs(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Apply a series of mutations (updates/deletes) to a row in a single transaction.
mutateRowTs(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
Mutation - Class in org.apache.hadoop.hbase.client
 
Mutation() - Constructor for class org.apache.hadoop.hbase.client.Mutation
 
Mutation - Class in org.apache.hadoop.hbase.thrift.generated
 
Mutation() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Mutation
 
Mutation(boolean, ByteBuffer, ByteBuffer, boolean) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Mutation
 
Mutation(Mutation) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Mutation
Performs a deep copy on other.
mutation - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.MutationReplay
 
Mutation._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MUTATION_OVERHEAD - Static variable in class org.apache.hadoop.hbase.client.Mutation
 
mutations - Variable in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
mutations - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
list of mutation commands
mutations - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
list of mutation commands
mutations - Variable in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
MutationSerialization - Class in org.apache.hadoop.hbase.mapreduce
 
MutationSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.MutationSerialization
 
mutator - Variable in class org.apache.hadoop.hbase.client.HTable
 
mvccVersion - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
mvccVersionDecoder - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
MvccVersionDecoder - Class in org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp
Given a block and its blockMeta, this will decode the MvccVersion for the i-th Cell in the block.
MvccVersionDecoder() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.MvccVersionDecoder
construct
mvccVersionDeltaWidth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
mvccVersionEncoder - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
mvccVersionIndexesOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
mvccVersionIndexWidth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
mvccVersions - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
MY_NAMESPACE_NAME - Static variable in class org.apache.hbase.archetypes.exemplars.client.HelloHBase
 
MY_NAMESPACE_NAME - Static variable in class org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
 

N

N - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'N'
name - Variable in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
 
NAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
name - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
File name to be used for block names
name - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Name for this object used when logging or in toString.
NAME - Static variable in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
NAME - Static variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
 
NAME - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
name - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
name - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
name - Variable in class org.apache.hadoop.metrics2.lib.MutableHistogram
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
NAMESPACE_COL_DESC_BYTES - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
NAMESPACE_DELIM - Static variable in class org.apache.hadoop.hbase.TableName
Namespace delimiter
NAMESPACE_DESC_PROP_GROUP - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
NAMESPACE_DESCRIPTOR_COMPARATOR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
NAMESPACE_FAMILY_INFO - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
NAMESPACE_FAMILY_INFO_BYTES - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
NAMESPACE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
NAMESPACE_PREFIX - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
 
NAMESPACE_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
The Namespace table's name.
NAMESPACE_TABLEDESC - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Table descriptor for namespace table
NamespaceAuditor - Class in org.apache.hadoop.hbase.namespace
The Class NamespaceAuditor performs checks to ensure operations like table creation and region splitting preserve namespace quota.
NamespaceAuditor(MasterServices) - Constructor for class org.apache.hadoop.hbase.namespace.NamespaceAuditor
 
NamespaceDescriptor - Class in org.apache.hadoop.hbase
Namespace POJO class.
NamespaceDescriptor.Builder - Class in org.apache.hadoop.hbase
 
NamespaceExistException - Exception in org.apache.hadoop.hbase
Thrown when a namespace exists but should not
NamespaceExistException() - Constructor for exception org.apache.hadoop.hbase.NamespaceExistException
 
NamespaceExistException(String) - Constructor for exception org.apache.hadoop.hbase.NamespaceExistException
 
NamespaceGroupingStrategy - Class in org.apache.hadoop.hbase.wal
A WAL grouping strategy based on namespace.
NamespaceGroupingStrategy() - Constructor for class org.apache.hadoop.hbase.wal.NamespaceGroupingStrategy
 
NamespaceModeStrategy - Class in org.apache.hadoop.hbase.hbtop.mode
Implementation for ModeStrategy for Namespace Mode.
NamespaceNotFoundException - Exception in org.apache.hadoop.hbase
Thrown when a namespace can not be located
NamespaceNotFoundException() - Constructor for exception org.apache.hadoop.hbase.NamespaceNotFoundException
 
NamespaceNotFoundException(String) - Constructor for exception org.apache.hadoop.hbase.NamespaceNotFoundException
 
NamespacePropertiesMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
NamespacePropertiesMessage.NamespaceProperties - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties
NamespacePropertiesMessage.NamespaceProperties.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties
NamespacePropertiesMessage.NamespaceProperties.Property - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property
NamespacePropertiesMessage.NamespaceProperties.Property.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property
NamespacePropertiesMessage.NamespaceProperties.PropertyOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
NamespacePropertiesMessage.NamespacePropertiesOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
NamespacesInstanceModel - Class in org.apache.hadoop.hbase.rest.model
List a HBase namespace's key/value properties.
NamespacesInstanceModel() - Constructor for class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
Default constructor.
NamespacesInstanceModel(String) - Constructor for class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
Constructor to use if namespace does not exist in HBASE.
NamespacesInstanceModel(Admin, String) - Constructor for class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
Constructor
NamespacesInstanceResource - Class in org.apache.hadoop.hbase.rest
Implements the following REST end points:
NamespacesInstanceResource(String) - Constructor for class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
Constructor for standard NamespaceInstanceResource.
NamespacesInstanceResource(String, boolean) - Constructor for class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
Constructor for querying namespace table list via NamespaceInstanceResource.
NamespacesMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
NamespacesMessage.Namespaces - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.Namespaces
NamespacesMessage.Namespaces.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.Namespaces
NamespacesMessage.NamespacesOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
NamespacesModel - Class in org.apache.hadoop.hbase.rest.model
A list of HBase namespaces.
NamespacesModel() - Constructor for class org.apache.hadoop.hbase.rest.model.NamespacesModel
Default constructor.
NamespacesModel(Admin) - Constructor for class org.apache.hadoop.hbase.rest.model.NamespacesModel
Constructor
NamespacesResource - Class in org.apache.hadoop.hbase.rest
Implements REST GET list of all namespaces.
NamespacesResource() - Constructor for class org.apache.hadoop.hbase.rest.NamespacesResource
Constructor
NamespaceUpgrade - Class in org.apache.hadoop.hbase.migration
Upgrades old 0.94 filesystem layout to namespace layout Does the following: - creates system namespace directory and move .META.
NamespaceUpgrade() - Constructor for class org.apache.hadoop.hbase.migration.NamespaceUpgrade
 
namespaceZNode - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
nameToType(String) - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
Map a checksum name to a specific type.
NANOS_PER_SECOND - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
 
navigableKeySet() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
NB_SEND - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
If a server dies, we're sending the information multiple times in case a receiver misses the message.
nbRows - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
number of results to return
needsBalance(BaseLoadBalancer.Cluster) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
needsBalance(BaseLoadBalancer.Cluster) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
needsClientAuth(boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
Specify whether the server should authorize the client in SSL connections.
needsCompaction(Collection<StoreFile>, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
Heuristics for guessing whether we need minor compaction.
needsCompaction(Collection<StoreFile>, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.FIFOCompactionPolicy
 
needsCompaction(Collection<StoreFile>, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
A heuristic method to decide whether to schedule a compaction request
needsCompaction(Collection<StoreFile>, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
 
needsCompaction(List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine
 
needsCompaction(List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
needsCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
needsCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Store
See if there's too much store files in this store
needsCompaction(List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
needsCompaction(List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
 
needsCompactions(StripeCompactionPolicy.StripeInformationProvider, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
 
needsQuoting(byte[], int, int) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
Does the given string need to be quoted?
needsQuoting(String) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
Does the given string need to be quoted?
needsSingleStripeCompaction(StripeCompactionPolicy.StripeInformationProvider) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
needsTuning() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
 
NeedUnmanagedConnectionException - Exception in org.apache.hadoop.hbase.client
Used for internal signalling that a Connection implementation needs to be user-managed to be used for particular request types.
NeedUnmanagedConnectionException() - Constructor for exception org.apache.hadoop.hbase.client.NeedUnmanagedConnectionException
 
negativeIndex - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
NEGOTIATE - Static variable in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
 
NettyHBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
Implement SASL logic for netty rpc client.
NettyHBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String) - Constructor for class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
 
NettyHBaseSaslRpcClientHandler - Class in org.apache.hadoop.hbase.security
Implement SASL logic for netty rpc client.
NettyHBaseSaslRpcClientHandler(Promise<Boolean>, UserGroupInformation, AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String) - Constructor for class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
NettyRpcClient - Class in org.apache.hadoop.hbase.ipc
Netty client for the requests and responses.
NettyRpcClient(Configuration, String, SocketAddress, MetricsConnection) - Constructor for class org.apache.hadoop.hbase.ipc.NettyRpcClient
 
NettyRpcClientConfigHelper - Class in org.apache.hadoop.hbase.ipc
Helper class for passing config to NettyRpcClient.
NettyRpcClientConfigHelper() - Constructor for class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
 
newBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Ready a new block for writing.
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
 
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
 
newBuilder() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
newBuilder(BulkDeleteProtos.BulkDeleteRequest) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
newBuilder(BulkDeleteProtos.BulkDeleteResponse) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
newBuilder(ExampleProtos.CountRequest) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
newBuilder(ExampleProtos.CountResponse) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
newBuilder(Field) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
 
newBuilder(Field, boolean) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.regionserver.ScannerContext
 
newBuilder(boolean) - Static method in class org.apache.hadoop.hbase.regionserver.ScannerContext
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
newBuilder(CellMessage.Cell) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
newBuilder(CellSetMessage.CellSet) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
newBuilder(CellSetMessage.CellSet.Row) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
newBuilder(ColumnSchemaMessage.ColumnSchema.Attribute) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
newBuilder(ColumnSchemaMessage.ColumnSchema) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
newBuilder(NamespacePropertiesMessage.NamespaceProperties) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
newBuilder(NamespacePropertiesMessage.NamespaceProperties.Property) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
newBuilder(NamespacesMessage.Namespaces) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
newBuilder(ScannerMessage.Scanner) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
newBuilder(StorageClusterStatusMessage.StorageClusterStatus) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
newBuilder(StorageClusterStatusMessage.StorageClusterStatus.Node) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
newBuilder(StorageClusterStatusMessage.StorageClusterStatus.Region) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
newBuilder(TableInfoMessage.TableInfo) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
newBuilder(TableInfoMessage.TableInfo.Region) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
newBuilder(TableListMessage.TableList) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
newBuilder(TableSchemaMessage.TableSchema.Attribute) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
newBuilder(TableSchemaMessage.TableSchema) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
newBuilder() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
newBuilder(VersionMessage.Version) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
newCaller(int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Create a new RetryingCaller with specific rpc timeout.
newCaller() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Create a new RetryingCaller with configured rpc timeout.
newCallStats() - Static method in class org.apache.hadoop.hbase.client.MetricsConnection
Produce an instance of MetricsConnection.CallStats for clients to attach to RPCs.
newConstructor(String) - Static method in class org.apache.hadoop.hbase.util.ChecksumFactory
Returns a Constructor that can be used to create a Checksum object.
newContext() - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
newContext(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
 
newController() - Method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
newController(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
newController(List<CellScannable>) - Method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
newCounter(String, String, long) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a mutable long integer counter
newCounter(MetricsInfo, long) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a mutable long integer counter
newDaemonThreadFactory(String) - Static method in class org.apache.hadoop.hbase.util.Threads
Same as {#newDaemonThreadFactory(String, UncaughtExceptionHandler)}, without setting the exception handler.
newDaemonThreadFactory(String, Thread.UncaughtExceptionHandler) - Static method in class org.apache.hadoop.hbase.util.Threads
Get a named ThreadFactory that just builds daemon threads.
newDataBlockDecodingContext(HFileContext) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
Deprecated.
 
newDataBlockDecodingContext(HFileContext) - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder
 
newDataBlockDecodingContext(HFileContext) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Creates an encoder specific decoding context, which will prepare the data before actual decoding
newDataBlockDecodingContext(HFileContext) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
create a encoder specific decoding context for reading.
newDataBlockDecodingContext(HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
newDataBlockDecodingContext(HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
newDataBlockEncodingContext(DataBlockEncoding, byte[], HFileContext) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
Deprecated.
 
newDataBlockEncodingContext(DataBlockEncoding, byte[], HFileContext) - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder
 
newDataBlockEncodingContext(DataBlockEncoding, byte[], HFileContext) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Creates a encoder specific encoding context
newDataBlockEncodingContext(byte[], HFileContext) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Create an encoder specific encoding context object for writing.
newDataBlockEncodingContext(byte[], HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
newDataBlockEncodingContext(byte[], HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
newGauge(String, String, long) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a mutable long integer gauge
newGauge(MetricsInfo, long) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a mutable long integer gauge
newHistogram(Sample) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
Create a new Histogram instance.
newHistogram(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a new histogram.
newHistogram(String, String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a new histogram.
newIncomingWindow(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionWindowFactory
 
newIncomingWindow(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory
 
newInstance(String) - Static method in class org.apache.hadoop.hbase.procedure2.Procedure
 
newInstance(Hbase.Iface, ThriftMetrics, Configuration) - Static method in class org.apache.hadoop.hbase.thrift.HbaseHandlerMetricsProxy
 
newInstance(THBaseService.Iface, ThriftMetrics) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
newInstance(String) - Static method in class org.apache.hadoop.hbase.util.ChecksumFactory
Create a new instance of a Checksum object.
newInstance(Class<T>, Object...) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
 
newNonce() - Method in interface org.apache.hadoop.hbase.client.NonceGenerator
 
newNonce() - Method in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
 
newPair(T1, T2) - Static method in class org.apache.hadoop.hbase.util.Pair
Constructs a new pair, inferring the type via the passed arguments
newRate(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a mutable rate metric
newRate(String, String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a mutable rate metric
newRate(String, String, boolean) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a mutable rate metric (for throughput measurement)
newRate(String, String, boolean, boolean) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
 
newReader(Configuration, ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
Open a TableHash.Reader starting at the first hash at or after the given key.
newReflectiveBlockingService(BulkDeleteProtos.BulkDeleteService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
 
newReflectiveBlockingService(ExampleProtos.RowCountService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
 
newReflectiveService(BulkDeleteProtos.BulkDeleteService.Interface) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
 
newReflectiveService(ExampleProtos.RowCountService.Interface) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
 
newServerSocket(String, int, int) - Method in class org.apache.hadoop.hbase.http.SslSocketConnectorSecure
Create a new ServerSocket that will not accept SSLv3 connections, but will accept TLSv1.x connections.
newServiceStub(Class<T>, RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
newSizeHistogram(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a new histogram with size range counts.
newSizeHistogram(String, String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a new histogram with size range counts.
newSplitAlgoInstance(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter
 
newStat(String, String, String, String, boolean) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a mutable metric with stats
newStat(String, String, String, String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a mutable metric with stats
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
 
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
 
newThread(Runnable) - Method in class org.apache.hadoop.hbase.DaemonThreadFactory
 
newTimeHistogram(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a new histogram with time range counts.
newTimeHistogram(String, String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Create a new histogram with time range counts.
newValue(Object) - Method in enum org.apache.hadoop.hbase.hbtop.field.Field
 
next(int) - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
Get nbRows rows.
next() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
next() - Method in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
 
next() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
Grab the next row's worth of values.
next(int) - Method in interface org.apache.hadoop.hbase.client.ResultScanner
 
next() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
 
next() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
next() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
Move to next position
next() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
next() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
next() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
Go to the next key/value in the block section.
next() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Scans to the next entry in the file.
next(ImmutableBytesWritable, Result) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
next(ImmutableBytesWritable, Result) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
next() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
Read the next key/hash pair.
next() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
 
next() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
 
next(List<Cell>) - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
Grab the next row's worth of values.
next(List<Cell>, ScannerContext) - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
Grab the next row's worth of values.
next() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
next(List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Gets the next row of keys from the top-most scanner.
next(List<Cell>, ScannerContext) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
next() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Return the next Cell in this scanner, iterating the scanner
next - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The next entry in the hash chain (for collisions)
next() - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
 
next() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
next() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
next(List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
next(List<Cell>, ScannerContext) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
Get the next row of values from this Store.
next() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
next(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
next() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
 
next() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
 
next() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
next() - Method in class org.apache.hadoop.hbase.types.StructIterator
 
next() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
next() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
 
next() - Method in interface org.apache.hadoop.hbase.wal.WAL.Reader
 
next(WAL.Entry) - Method in interface org.apache.hadoop.hbase.wal.WAL.Reader
 
nextAsProcedure() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureIterator
Returns the next procedure in the iteration.
nextAsProcedureInfo() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureIterator
 
nextBytes(byte[]) - Method in class org.apache.hadoop.hbase.util.Random64
 
nextEarlierWindow() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionWindow
Move to the new window of the same tier or of the next tier, which represents an earlier time span.
nextIndexedKey - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
The next indexed key is to keep track of the indexed key of the next data block.
nextKeyValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Positions the record reader to the next record.
nextKeyValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Positions the record reader to the next record.
nextKeyValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
 
nextKvOffset - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
nextLong() - Method in class org.apache.hadoop.hbase.util.Random64
 
nextNodeId() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
nextNodeOffsetsOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
nextNodeOffsetWidth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
nextPtr - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The next entry in the LRU list (towards MRU)
nextRaw(List<Cell>) - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
Grab the next row's worth of values.
nextRaw(List<Cell>, ScannerContext) - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
Grab the next row's worth of values.
nextRow() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
nextRowInternal() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
This method is safe to call when the scanner is not on a fully valid row node, as in the case of a row token miss in the Searcher
nextScannerId - Variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
nextShallowCopy(ByteBuffer, boolean, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Creates a new KeyValue object positioned in the supplied ByteBuffer and sets the ByteBuffer's position to the start of the next KeyValue.
nextWasCalled - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
 
NINE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code foe Nine
NINES - Static variable in class org.apache.hadoop.hbase.HConstants
 
NINETIETH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
NINETY_EIGHTH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
NINETY_FIFTH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
NINETY_NINE_POINT_NINETH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
NINETY_NINETH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
NO_CACHE_FILTER - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
NO_HASH - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
NO_NEXT_INDEXED_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
The byte array represents for NO_NEXT_INDEXED_KEY; The actual value is irrelevant because this is always compared by reference.
NO_NONCE - Static variable in class org.apache.hadoop.hbase.HConstants
 
NO_OPTIONS - Static variable in class org.apache.hadoop.hbase.util.Base64
No options specified.
NO_PRIORITY - Static variable in interface org.apache.hadoop.hbase.regionserver.Store
 
NO_SEQNUM - Static variable in class org.apache.hadoop.hbase.HConstants
Value indicating the server name was saved with no sequence number.
NO_SEQUENCE_ID - Static variable in class org.apache.hadoop.hbase.wal.WALKey
Used to represent when a particular wal key doesn't know/care about the sequence ordering.
NO_SNAPSHOT_START_TIME_SPECIFIED - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Default value if no start time is specified
NO_STRICT_COL_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
NOCACHE_PARAM_NAME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
If this query parameter is present when processing row or scanner resources, it disables server side block caching
NoCacheFilter - Class in org.apache.hadoop.hbase.http
 
NoCacheFilter() - Constructor for class org.apache.hadoop.hbase.http.NoCacheFilter
 
node - Static variable in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
 
node - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Path of node being tracked
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
 
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
Override handler from ZooKeeperListener
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
New unassigned node has been created.
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.PeerRegionServerListener
 
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.OtherRegionServerWatcher
Called when an existing node has a child node added or removed.
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.PeersWatcher
Called when an existing node has a child node added or removed.
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
 
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
 
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
 
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.DrainingServerTracker
 
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
 
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.RecoveringRegionWatcher
 
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
 
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Called when an existing node has a child node added or removed.
nodeCreated(String) - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
 
nodeCreated(String) - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
 
nodeCreated(String) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
New unassigned node has been created.
nodeCreated(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerConfigTracker
 
nodeCreated(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.OtherRegionServerWatcher
Called when a new node has been created.
nodeCreated(String) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
 
nodeCreated(String) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
nodeCreated(String) - Method in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
 
nodeCreated(String) - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
 
nodeCreated(String) - Method in class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
 
nodeCreated(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
 
nodeCreated(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Called when a new node has been created.
nodeCreated(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
Override handler from ZooKeeperListener
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Existing unassigned node has had data changed.
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerConfigTracker
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerStateTracker
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.RecoveringRegionWatcher
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Called when an existing node has changed data.
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.OtherRegionServerWatcher
Called when a node has been deleted
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.PeersWatcher
Called when a node has been deleted
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.DrainingServerTracker
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.RecoveringRegionWatcher
Called when a node has been deleted
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Called when a node has been deleted
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
nodeDepth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
nodeHasChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Checks if the specified znode has any children.
nodes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
nodes - Variable in class org.apache.hadoop.hbase.rest.client.Cluster
 
nodeType - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
nodeType - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
 
nodeType - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
 
NoLimitScannerContext - Class in org.apache.hadoop.hbase.regionserver
This is a special ScannerContext subclass that is designed to be used globally when limits should not be enforced during invocations of InternalScanner.next(java.util.List) or InternalScanner.next(java.util.List).
NoLimitScannerContext() - Constructor for class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
 
NoLimitThroughputController - Class in org.apache.hadoop.hbase.regionserver.throttle
 
NoLimitThroughputController() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
 
NON_EXIST_LABEL_ORDINAL - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Label ordinal value for invalid labels
NON_STARTCODE - Static variable in class org.apache.hadoop.hbase.ServerName
What to use if no startcode supplied.
nonce - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.MutationReplay
 
NonceGenerator - Interface in org.apache.hadoop.hbase.client
NonceGenerator interface.
nonceGroup - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.MutationReplay
 
NonceKey - Class in org.apache.hadoop.hbase.util
This implementation is not smart and just treats nonce group and nonce as random bits.
NonceKey(long, long) - Constructor for class org.apache.hadoop.hbase.util.NonceKey
 
NONE - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
The null crypto context
NONE - Static variable in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Represents no value, or not set.
NoneEncoder - Class in org.apache.hadoop.hbase.io.encoding
 
NoneEncoder(DataOutputStream, HFileBlockDefaultEncodingContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.NoneEncoder
 
NonLazyKeyValueScanner - Class in org.apache.hadoop.hbase.regionserver
A "non-lazy" scanner which always does a real seek operation.
NonLazyKeyValueScanner() - Constructor for class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
 
NonLeafExpressionNode - Class in org.apache.hadoop.hbase.security.visibility.expression
 
NonLeafExpressionNode() - Constructor for class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
 
NonLeafExpressionNode(Operator) - Constructor for class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
 
NonLeafExpressionNode(Operator, List<ExpressionNode>) - Constructor for class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
 
NonLeafExpressionNode(Operator, ExpressionNode...) - Constructor for class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
 
nonLeafWriters - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
nonLeaves - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
NonReversedNonLazyKeyValueScanner - Class in org.apache.hadoop.hbase.regionserver
A "non-reversed & non-lazy" scanner which does not support backward scanning and always does a real seek operation.
NonReversedNonLazyKeyValueScanner() - Constructor for class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
 
NoOpDataBlockEncoder - Class in org.apache.hadoop.hbase.io.hfile
Does not perform any kind of encoding/decoding.
NoOpHeapMemoryTuner - Class in org.apache.hadoop.hbase.regionserver
An implementation of HeapMemoryTuner which is not doing any tuning activity but just allows to continue with old style fixed proportions.
NoOpHeapMemoryTuner() - Constructor for class org.apache.hadoop.hbase.regionserver.NoOpHeapMemoryTuner
 
NoopProcedureStore - Class in org.apache.hadoop.hbase.procedure2.store
An In-Memory store that does not keep track of the procedures inserted.
NoopProcedureStore() - Constructor for class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
 
normal() - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
 
NORMAL_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by shell/rest interface to access this metadata attribute which denotes if the table should be treated by region normalizer.
NormalizationPlan - Interface in org.apache.hadoop.hbase.master.normalizer
Interface for normalization plan.
NormalizationPlan.PlanType - Enum in org.apache.hadoop.hbase.master.normalizer
 
normalize() - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke region normalizer.
normalize() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Invoke region normalizer.
normalize(RpcController, MasterProtos.NormalizeRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
normalizeRegions() - Method in class org.apache.hadoop.hbase.master.HMaster
Perform normalization of cluster (invoked by RegionNormalizerChore).
normalizerSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Sets normalizer on/off flag in ZK.
NormalUserScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
Query matcher for normal user scan.
NormalUserScanQueryMatcher(Scan, ScanInfo, ColumnTracker, boolean, DeleteTracker, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
 
NoServerForRegionException - Exception in org.apache.hadoop.hbase.client
Thrown when no region server can be found for a region
NoServerForRegionException() - Constructor for exception org.apache.hadoop.hbase.client.NoServerForRegionException
default constructor
NoServerForRegionException(String) - Constructor for exception org.apache.hadoop.hbase.client.NoServerForRegionException
Constructor
NoSuchColumnFamilyException - Exception in org.apache.hadoop.hbase.regionserver
Thrown if request for nonexistent column family.
NoSuchColumnFamilyException() - Constructor for exception org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
default constructor
NoSuchColumnFamilyException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
 
NOT_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
NOT_EQUAL_TO Array
NOT_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
NOT_IN_DICTIONARY - Static variable in interface org.apache.hadoop.hbase.io.util.Dictionary
 
NOT_OPERATOR - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
NOT_RUN - Static variable in class org.apache.hadoop.hbase.regionserver.OperationStatus
Singleton for operations not yet run.
NOT_SERVING_REGION_EXCEPTION_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
NoTagsKeyValue - Class in org.apache.hadoop.hbase
An extension of the KeyValue where the tags length is always 0
NoTagsKeyValue(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.NoTagsKeyValue
 
NotAllMetaRegionsOnlineException - Exception in org.apache.hadoop.hbase
Thrown when an operation requires the root and all meta regions to be online
NotAllMetaRegionsOnlineException() - Constructor for exception org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException
default constructor
NotAllMetaRegionsOnlineException(String) - Constructor for exception org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException
 
notDoubleEquals(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
notDoubleEquals(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
notEmpty(Collection<T>) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
 
notEqual(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
notEqual(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
notGreater(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
notGreater(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
notGreaterOrEqual(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
notGreaterOrEqual(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
notifyAllObservers(Configuration) - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
The conf object has been repopulated from disk, and we have to notify all the observers that are expressed interest to do that.
notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
notifyOnCancel(RpcCallback<Object>, HBaseRpcController.CancellationCallback) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
notifyOnCancel(RpcCallback<Object>) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
A little different from the basic RpcController: You can register multiple callbacks to an HBaseRpcController. The callback will not be called if the rpc call is finished without any cancellation. You can call me at client side also.
notifyOnCancel(RpcCallback<Object>, HBaseRpcController.CancellationCallback) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
If not cancelled, add the callback to cancellation callback list.
notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
notifyOnCancel(RpcCallback<Object>, HBaseRpcController.CancellationCallback) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
notifyServer(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
Notify that we started processing this dead server.
notLess(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
notLess(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
notLessOrEqual(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
notLessOrEqual(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
notServingRegionException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
notServingRegionException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
NotServingRegionException - Exception in org.apache.hadoop.hbase
Thrown by a region server if it is sent a request for a region it is not serving.
NotServingRegionException() - Constructor for exception org.apache.hadoop.hbase.NotServingRegionException
 
NotServingRegionException(String) - Constructor for exception org.apache.hadoop.hbase.NotServingRegionException
 
NotServingRegionException(byte[]) - Constructor for exception org.apache.hadoop.hbase.NotServingRegionException
 
now - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
now - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
nubCellsRemain - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
NullAction - Static variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
 
NullComparator - Class in org.apache.hadoop.hbase.filter
A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
NullComparator() - Constructor for class org.apache.hadoop.hbase.filter.NullComparator
 
nullifyCurrentHeap() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
nullSafe(Collection<T>) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
 
nullSafe(Iterable<T>) - Static method in class org.apache.hadoop.hbase.util.IterableUtils
 
nullSafeSameSize(Collection<A>, Collection<B>) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
 
nullSafeSize(Collection<T>) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
size
NUM_ACTIVE_HANDLER_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_ACTIVE_HANDLER_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_ACTIVE_READ_HANDLER_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_ACTIVE_READ_HANDLER_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_ACTIVE_SCAN_HANDLER_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_ACTIVE_SCAN_HANDLER_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_ACTIVE_WRITE_HANDLER_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_ACTIVE_WRITE_HANDLER_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_BYTES_COMPACTED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
NUM_BYTES_COMPACTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
NUM_DEAD_REGION_SERVERS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
NUM_FILES_COMPACTED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
NUM_FILES_COMPACTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
NUM_GENERAL_CALLS_DROPPED_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_GENERAL_CALLS_DROPPED_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_INTS - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
NUM_LIFO_MODE_SWITCHES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_LIFO_MODE_SWITCHES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_LONGS - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
NUM_MAPPERS_PER_REGION - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Set the number of Mappers for each region, all regions have same number of Mappers
NUM_MASTER_WALS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
 
NUM_MASTER_WALS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
 
NUM_OPEN_CONNECTIONS_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_OPEN_CONNECTIONS_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
NUM_OPS_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
NUM_REFERENCE_FILES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
NUM_REFERENCE_FILES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
NUM_REGION_SERVERS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
NUM_REGIONS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
 
NUM_SHORTS - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
NUM_SINGLE_BYTES - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
NUM_SPLITS_PER_REGION - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
For MapReduce jobs running multiple mappers per region, determines number of splits to generate per region.
NUM_TABLES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
 
numArraysAdded - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
fields
NUMBER_OF_DEAD_REGION_SERVERS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
NUMBER_OF_MUTATIONS_WITHOUT_WAL - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
NUMBER_OF_MUTATIONS_WITHOUT_WAL_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
NUMBER_OF_REGION_SERVERS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
NUMBER_OF_REGIONS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
 
NUMBER_OF_TABLES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
 
NUMBER_OF_THREADS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
 
numBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
numBytes - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
numBytes(long) - Static method in class org.apache.hadoop.hbase.util.vint.UFIntTool
 
numBytes(int) - Static method in class org.apache.hadoop.hbase.util.vint.UVIntTool
int -> bytes
numBytes(long) - Static method in class org.apache.hadoop.hbase.util.vint.UVLongTool
long -> bytes
numCallQueues - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
numCells - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
numCells - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
numChunks - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
At read time, the total number of chunks.
numConnections - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
numEqualPrefixBytes(ByteRange, ByteRange, int) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
 
numFamilies() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the number of families to get from
numFamilies() - Method in class org.apache.hadoop.hbase.client.Increment
Method for retrieving the number of families to increment from
numFamilies() - Method in class org.apache.hadoop.hbase.client.Mutation
 
numFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
 
numFamilyBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
numIdenticalBytes(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
numInputs - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
numKeyValueBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
numLeafWriters - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
numMetaBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
numMvccVersionBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
numNodes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
numNonLeafWriters - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
numNonNullElements() - Method in class org.apache.hadoop.hbase.RegionLocations
Returns the size of not-null locations
numOccurrences - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
numQualifierBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
numRegionsToReport - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
numResets - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
fields
numRowBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
numRows - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
number of rows to return
numRows - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
number of rows to return
numTagsBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
numThreads - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
numTimestampBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
numUniqueFamilies - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
numUniqueQualifiers - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
numUniqueRanges - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
numUniqueRows - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
numUniqueTags - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
numValueBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
numVersions - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
number of versions to retrieve
numVersions - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
number of versions to retrieve

O

O - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'O'
OBJECT - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Object overhead is minimum 2 * reference size (8 bytes on 64-bit)
ObserverContext<E extends CoprocessorEnvironment> - Class in org.apache.hadoop.hbase.coprocessor
Carries the execution state for a given invocation of an Observer coprocessor (RegionObserver, MasterObserver, or WALObserver) method.
ObserverContext() - Constructor for class org.apache.hadoop.hbase.coprocessor.ObserverContext
 
obtainAndCacheToken(Configuration, UserGroupInformation) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
obtainAndCacheToken(Connection, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Obtain an authentication token for the given user and add it to the user's credentials.
obtainAuthTokenForJob(Configuration, Job) - Method in class org.apache.hadoop.hbase.security.User
Deprecated.
Use TokenUtil.obtainAuthTokenForJob(Connection,User,Job) instead.
obtainAuthTokenForJob(JobConf) - Method in class org.apache.hadoop.hbase.security.User
Deprecated.
Use TokenUtil.obtainAuthTokenForJob(Connection,JobConf,User) instead.
obtainAuthTokenForJob(Configuration, Job) - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
 
obtainAuthTokenForJob(JobConf) - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
 
obtainServerLoadPB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
obtainToken(Configuration) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Deprecated.
obtainToken(Connection) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Obtain and return an authentication token for the current user.
obtainToken(Connection, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Obtain and return an authentication token for the current user.
obtainTokenForJob(Configuration, UserGroupInformation, Job) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
obtainTokenForJob(Connection, User, Job) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job.
obtainTokenForJob(JobConf, UserGroupInformation) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
obtainTokenForJob(Connection, JobConf, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job.
ofEntries(Record.Entry...) - Static method in class org.apache.hadoop.hbase.hbtop.Record
 
ofEntries(Iterable<Record.Entry>) - Static method in class org.apache.hadoop.hbase.hbtop.Record
 
offer(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
offer(CallRunner, long, TimeUnit) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
offer(Runnable) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
offer(Runnable, long, TimeUnit) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
offer(E) - Method in class org.apache.hadoop.hbase.util.BoundedArrayQueue
 
offer(E) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
offer(E, long, TimeUnit) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
offer(T) - Method in class org.apache.hadoop.hbase.util.StealJobQueue
 
offline(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Offline specified region from master's in-memory state.
offline(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Offline specified region from master's in-memory state.
offline - Variable in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
OfflineCallback - Class in org.apache.hadoop.hbase.master
Callback handler for creating unassigned offline znodes used during bulk assign, async setting region to offline.
offlineDisabledRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
offlineHdfsIntegrityRepair() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
This repair method analyzes hbase data in hdfs and repairs it to satisfy the table integrity rules.
OfflineMetaRepair - Class in org.apache.hadoop.hbase.util.hbck
This code is used to rebuild meta off line from file system data.
OfflineMetaRepair() - Constructor for class org.apache.hadoop.hbase.util.hbck.OfflineMetaRepair
 
offlineRegion(RpcController, MasterProtos.OfflineRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Offline specified region from master's in-memory state.
OffPeakHours - Class in org.apache.hadoop.hbase.regionserver.compactions
 
OffPeakHours() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
 
offPeakHours - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
offset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
offset - Variable in class org.apache.hadoop.hbase.KeyValue
 
offset - Variable in class org.apache.hadoop.hbase.util.AbstractByteRange
The index of the first byte in this range.
offsetIntoBlock - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
OLD_META_STR - Static variable in class org.apache.hadoop.hbase.TableName
 
OLD_META_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
TableName for old .META.
OLD_ROOT_STR - Static variable in class org.apache.hadoop.hbase.TableName
 
OLD_ROOT_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
TableName for old -ROOT- table.
OLD_SNAPSHOT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
OLD_WALS_CLEANER_THREAD_CHECK_INTERVAL_MSEC - Static variable in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
 
OLD_WALS_CLEANER_THREAD_SIZE - Static variable in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
 
OLD_WALS_CLEANER_THREAD_TIMEOUT_MSEC - Static variable in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
 
OLDEST_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
Should not be public since hbase-1.3.0. For internal use only. Move internal to Scanners flagged as special timestamp value never to be returned as timestamp on a Cell.
oldestUnexpiredTS - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
The oldest timestamp we are interested in, based on TTL
oldestUnexpiredTS - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
onChoreMissedStartTime(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
 
onConfigurationChange(Configuration) - Method in interface org.apache.hadoop.hbase.conf.ConfigurationObserver
This method would be called by the ConfigurationManager object when the Configuration object is reloaded from disk.
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.DirScanPool
Checks if pool can be updated.
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
 
onConfigurationChange(Configuration) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
 
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
This method would be called by the ConfigurationManager object when the Configuration object is reloaded from disk.
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
This method would be called by the ConfigurationManager object when the Configuration object is reloaded from disk.
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.HStore
This method would be called by the ConfigurationManager object when the Configuration object is reloaded from disk.
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
OnePhaseProcedure<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
 
OnePhaseProcedure() - Constructor for class org.apache.hadoop.hbase.procedure2.OnePhaseProcedure
 
onException(RetriesExhaustedWithDetailsException, BufferedMutator) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator.ExceptionListener
 
ONLINE_SNAPSHOT_CONTROLLER_DESCRIPTION - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Name of the operation to use in the controller
onlineConsistencyRepair() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
This repair method requires the cluster to be online since it contacts region servers and the masters.
onlineHbck() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Contacts the master and prints out cluster-wide information
onlineRegions - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
Map of regions currently being served by this region server.
OnlineRegions - Interface in org.apache.hadoop.hbase.regionserver
Interface to Map of online regions.
onlyType - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
 
onRegionMerged(HRegionInfo) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
onRegionMerged(HRegionInfo) - Method in interface org.apache.hadoop.hbase.RegionStateListener
Process region merge event.
onRegionSplit(HRegionInfo) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
onRegionSplit(HRegionInfo) - Method in interface org.apache.hadoop.hbase.RegionStateListener
Process region split event.
onRegionSplitReverted(HRegionInfo) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
onRegionSplitReverted(HRegionInfo) - Method in interface org.apache.hadoop.hbase.RegionStateListener
Process region split reverted event.
onRegionTransition(ServerName, RegionServerStatusProtos.RegionStateTransition) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Try to update some region states.
OP_ATTRIBUTE_ACL - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Cell level ACL
OP_ATTRIBUTE_ACL_STRATEGY - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Deprecated.
OP_ATTRIBUTE_ACL_STRATEGY_CELL_FIRST - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Deprecated.
OP_ATTRIBUTE_ACL_STRATEGY_DEFAULT - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
Deprecated.
open(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
Open the FileLink for read.
open(FileSystem, int) - Method in class org.apache.hadoop.hbase.io.FileLink
Open the FileLink for read.
open(InputStream) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueDeserializer
 
open(OutputStream) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
 
open() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
open(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
Open a QuotaRetriever with no filter, all the quota settings will be returned.
open(Configuration, QuotaFilter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
Open a QuotaRetriever with the specified filter.
OPEN - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
open(FileSystem, CacheConfig, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Open a Reader for the StoreFile
open(Configuration, FileSystem, Path, HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Return a SnapshotManifest instance with the information already loaded in-memory.
open(PrintWriter) - Method in class org.apache.hadoop.hbase.util.JSONBean
Notice that, closing the return JSONBean.Writer will not close the writer passed in, you still need to close the writer by yourself.
OPEN_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
The key value used for range boundary, indicating that the boundary is open (i.e.
OPEN_PARAN - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
OPEN_PARAN_NODE - Static variable in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
 
OpenedRegionHandler - Class in org.apache.hadoop.hbase.master.handler
Handles OPENED region event on Master.
OpenedRegionHandler(Server, AssignmentManager, HRegionInfo, OpenRegionCoordination, OpenRegionCoordination.OpenRegionDetails) - Constructor for class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
 
openHRegion(HRegionInfo, HTableDescriptor, WAL, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Open a Region.
openHRegion(HRegionInfo, HTableDescriptor, WAL, Configuration, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Open a Region.
openHRegion(Path, HRegionInfo, HTableDescriptor, WAL, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Open a Region.
openHRegion(Path, HRegionInfo, HTableDescriptor, WAL, Configuration, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Open a Region.
openHRegion(Configuration, FileSystem, Path, HRegionInfo, HTableDescriptor, WAL) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Open a Region.
openHRegion(Configuration, FileSystem, Path, HRegionInfo, HTableDescriptor, WAL, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Open a Region.
openHRegion(Configuration, FileSystem, Path, Path, HRegionInfo, HTableDescriptor, WAL, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Open a Region.
openHRegion(HRegion, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Useful when reopening a closed region (normally for unit tests)
openHRegion(Region, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
 
openHRegion(CancelableProgressable) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Open HRegion.
OpenMetaHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handles opening of a meta region on a region server.
OpenMetaHandler(Server, RegionServerServices, HRegionInfo, HTableDescriptor, long, OpenRegionCoordination, OpenRegionCoordination.OpenRegionDetails) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.OpenMetaHandler
 
OpenPriorityRegionHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handles opening of a high priority region on a region server.
OpenPriorityRegionHandler(Server, RegionServerServices, HRegionInfo, HTableDescriptor, long, OpenRegionCoordination, OpenRegionCoordination.OpenRegionDetails) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.OpenPriorityRegionHandler
 
openReadOnlyFileSystemHRegion(Configuration, FileSystem, Path, HRegionInfo, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Open a Region on a read-only file-system (like hdfs snapshots)
openRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, HRegionInfo) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to open a region using admin protocol.
openRegion(RpcController, AdminProtos.OpenRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Open asynchronously a region or a set of regions on the region server.
OpenRegionCoordination - Interface in org.apache.hadoop.hbase.coordination
Cocoordination operations for opening regions.
openRegionCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
OpenRegionCoordination.OpenRegionDetails - Interface in org.apache.hadoop.hbase.coordination
Interface for region opening tasks.
openRegionFromFileSystem(Configuration, FileSystem, Path, HRegionInfo, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Open Region from file-system.
OpenRegionHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handles opening of a region on a region server.
OpenRegionHandler(Server, RegionServerServices, HRegionInfo, HTableDescriptor, long, OpenRegionCoordination, OpenRegionCoordination.OpenRegionDetails) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
 
OpenRegionHandler(Server, RegionServerServices, HRegionInfo, HTableDescriptor, EventType, long, OpenRegionCoordination, OpenRegionCoordination.OpenRegionDetails) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
 
openScanner(ByteBuffer, TScan, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
openScanner(ByteBuffer, TScan, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
openScanner(ByteBuffer, TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
openScanner(ByteBuffer, TScan) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Get a Scanner for the provided TScan object.
openScanner(ByteBuffer, TScan) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
openTables - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
Accounting for tables opened by the coprocessor
Operation - Class in org.apache.hadoop.hbase.client
Superclass for any type that maps to a potentially application-level query.
Operation() - Constructor for class org.apache.hadoop.hbase.client.Operation
 
OperationConflictException - Exception in org.apache.hadoop.hbase.exceptions
The exception that is thrown if there's duplicate execution of non-idempotent operation.
OperationConflictException() - Constructor for exception org.apache.hadoop.hbase.exceptions.OperationConflictException
 
OperationConflictException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.OperationConflictException
 
OperationConflictException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.OperationConflictException
 
OperationConflictException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.OperationConflictException
 
OperationQuota - Interface in org.apache.hadoop.hbase.quotas
Interface that allows to check the quota available for an operation.
OperationQuota.OperationType - Enum in org.apache.hadoop.hbase.quotas
 
OperationStatus - Class in org.apache.hadoop.hbase.regionserver
This class stores the Operation status code and the exception message that occurs in case of failure of operations like put, delete, etc.
OperationStatus(HConstants.OperationStatusCode) - Constructor for class org.apache.hadoop.hbase.regionserver.OperationStatus
 
OperationStatus(HConstants.OperationStatusCode, String) - Constructor for class org.apache.hadoop.hbase.regionserver.OperationStatus
 
OperationStatus(HConstants.OperationStatusCode, Exception) - Constructor for class org.apache.hadoop.hbase.regionserver.OperationStatus
 
operationTypesOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
OperationWithAttributes - Class in org.apache.hadoop.hbase.client
 
OperationWithAttributes() - Constructor for class org.apache.hadoop.hbase.client.OperationWithAttributes
 
Operator - Enum in org.apache.hadoop.hbase.security.visibility.expression
 
OPS_SAMPLE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
optionLength(String) - Static method in class org.apache.hadoop.hbase.classification.tools.ExcludePrivateAnnotationsStandardDoclet
 
optionLength(String) - Static method in class org.apache.hadoop.hbase.classification.tools.IncludePublicAnnotationsStandardDoclet
 
OR - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
OR Byte Array
OR_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
OR Array
OR_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
OR_OPERATOR - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
order - Variable in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
order - Variable in class org.apache.hadoop.hbase.types.RawBytes
 
order - Variable in class org.apache.hadoop.hbase.types.RawString
 
Order - Enum in org.apache.hadoop.hbase.util
Used to describe or modify the lexicographical sort order of a byte[].
ORDERED - Static variable in class org.apache.hadoop.hbase.util.Base64
Encode using the special "ordered" dialect of Base64 described here: http://www.faqs.org/qa/rfcc-1940.html.
OrderedBlob - Class in org.apache.hadoop.hbase.types
A byte[] of variable-length.
OrderedBlob(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedBlob
 
OrderedBlobVar - Class in org.apache.hadoop.hbase.types
An alternative to OrderedBlob for use by Struct fields that do not terminate the fields list.
OrderedBlobVar(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedBlobVar
 
OrderedBytes - Class in org.apache.hadoop.hbase.util
Utility class that handles ordered byte arrays.
OrderedBytes() - Constructor for class org.apache.hadoop.hbase.util.OrderedBytes
 
OrderedBytesBase<T> - Class in org.apache.hadoop.hbase.types
Base class for data types backed by the OrderedBytes encoding implementations.
OrderedBytesBase(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedBytesBase
 
OrderedFloat32 - Class in org.apache.hadoop.hbase.types
A float of 32-bits using a fixed-length encoding.
OrderedFloat32(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedFloat32
 
OrderedFloat64 - Class in org.apache.hadoop.hbase.types
A double of 64-bits using a fixed-length encoding.
OrderedFloat64(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedFloat64
 
OrderedInt16 - Class in org.apache.hadoop.hbase.types
A short of 16-bits using a fixed-length encoding.
OrderedInt16(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedInt16
 
OrderedInt32 - Class in org.apache.hadoop.hbase.types
An int of 32-bits using a fixed-length encoding.
OrderedInt32(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedInt32
 
OrderedInt64 - Class in org.apache.hadoop.hbase.types
A long of 64-bits using a fixed-length encoding.
OrderedInt64(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedInt64
 
OrderedInt8 - Class in org.apache.hadoop.hbase.types
A byte of 8-bits using a fixed-length encoding.
OrderedInt8(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedInt8
 
OrderedNumeric - Class in org.apache.hadoop.hbase.types
An Number of arbitrary precision and variable-length encoding.
OrderedNumeric(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedNumeric
 
OrderedString - Class in org.apache.hadoop.hbase.types
A String of variable-length.
OrderedString(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedString
 
org.apache.hadoop.hbase - package org.apache.hadoop.hbase
 
org.apache.hadoop.hbase.backup - package org.apache.hadoop.hbase.backup
 
org.apache.hadoop.hbase.backup.example - package org.apache.hadoop.hbase.backup.example
 
org.apache.hadoop.hbase.classification - package org.apache.hadoop.hbase.classification
 
org.apache.hadoop.hbase.classification.tools - package org.apache.hadoop.hbase.classification.tools
 
org.apache.hadoop.hbase.client - package org.apache.hadoop.hbase.client
Provides HBase Client
org.apache.hadoop.hbase.client.backoff - package org.apache.hadoop.hbase.client.backoff
 
org.apache.hadoop.hbase.client.coprocessor - package org.apache.hadoop.hbase.client.coprocessor
Provides client classes for invoking Coprocessor RPC protocols Overview Example Usage
org.apache.hadoop.hbase.client.example - package org.apache.hadoop.hbase.client.example
 
org.apache.hadoop.hbase.client.metrics - package org.apache.hadoop.hbase.client.metrics
 
org.apache.hadoop.hbase.client.replication - package org.apache.hadoop.hbase.client.replication
 
org.apache.hadoop.hbase.client.security - package org.apache.hadoop.hbase.client.security
 
org.apache.hadoop.hbase.codec - package org.apache.hadoop.hbase.codec
 
org.apache.hadoop.hbase.codec.prefixtree - package org.apache.hadoop.hbase.codec.prefixtree
 
org.apache.hadoop.hbase.codec.prefixtree.decode - package org.apache.hadoop.hbase.codec.prefixtree.decode
 
org.apache.hadoop.hbase.codec.prefixtree.decode.column - package org.apache.hadoop.hbase.codec.prefixtree.decode.column
 
org.apache.hadoop.hbase.codec.prefixtree.decode.row - package org.apache.hadoop.hbase.codec.prefixtree.decode.row
 
org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp - package org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp
 
org.apache.hadoop.hbase.codec.prefixtree.encode - package org.apache.hadoop.hbase.codec.prefixtree.encode
 
org.apache.hadoop.hbase.codec.prefixtree.encode.column - package org.apache.hadoop.hbase.codec.prefixtree.encode.column
 
org.apache.hadoop.hbase.codec.prefixtree.encode.other - package org.apache.hadoop.hbase.codec.prefixtree.encode.other
 
org.apache.hadoop.hbase.codec.prefixtree.encode.row - package org.apache.hadoop.hbase.codec.prefixtree.encode.row
 
org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize - package org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize
 
org.apache.hadoop.hbase.codec.prefixtree.scanner - package org.apache.hadoop.hbase.codec.prefixtree.scanner
 
org.apache.hadoop.hbase.conf - package org.apache.hadoop.hbase.conf
 
org.apache.hadoop.hbase.constraint - package org.apache.hadoop.hbase.constraint
Restrict the domain of a data attribute, often times to fulfill business rules/requirements.
org.apache.hadoop.hbase.coordination - package org.apache.hadoop.hbase.coordination
 
org.apache.hadoop.hbase.coprocessor - package org.apache.hadoop.hbase.coprocessor
Table of Contents
org.apache.hadoop.hbase.coprocessor.example - package org.apache.hadoop.hbase.coprocessor.example
 
org.apache.hadoop.hbase.coprocessor.example.generated - package org.apache.hadoop.hbase.coprocessor.example.generated
 
org.apache.hadoop.hbase.errorhandling - package org.apache.hadoop.hbase.errorhandling
 
org.apache.hadoop.hbase.exceptions - package org.apache.hadoop.hbase.exceptions
 
org.apache.hadoop.hbase.executor - package org.apache.hadoop.hbase.executor
 
org.apache.hadoop.hbase.filter - package org.apache.hadoop.hbase.filter
Provides row-level filters applied to HRegion scan results during calls to ResultScanner.next().
org.apache.hadoop.hbase.fs - package org.apache.hadoop.hbase.fs
 
org.apache.hadoop.hbase.generated.regionserver - package org.apache.hadoop.hbase.generated.regionserver
 
org.apache.hadoop.hbase.generated.rest - package org.apache.hadoop.hbase.generated.rest
 
org.apache.hadoop.hbase.generated.thrift - package org.apache.hadoop.hbase.generated.thrift
 
org.apache.hadoop.hbase.hbtop - package org.apache.hadoop.hbase.hbtop
 
org.apache.hadoop.hbase.hbtop.field - package org.apache.hadoop.hbase.hbtop.field
 
org.apache.hadoop.hbase.hbtop.mode - package org.apache.hadoop.hbase.hbtop.mode
 
org.apache.hadoop.hbase.hbtop.screen - package org.apache.hadoop.hbase.hbtop.screen
 
org.apache.hadoop.hbase.hbtop.screen.field - package org.apache.hadoop.hbase.hbtop.screen.field
 
org.apache.hadoop.hbase.hbtop.screen.help - package org.apache.hadoop.hbase.hbtop.screen.help
 
org.apache.hadoop.hbase.hbtop.screen.mode - package org.apache.hadoop.hbase.hbtop.screen.mode
 
org.apache.hadoop.hbase.hbtop.screen.top - package org.apache.hadoop.hbase.hbtop.screen.top
 
org.apache.hadoop.hbase.hbtop.terminal - package org.apache.hadoop.hbase.hbtop.terminal
 
org.apache.hadoop.hbase.hbtop.terminal.impl - package org.apache.hadoop.hbase.hbtop.terminal.impl
 
org.apache.hadoop.hbase.http - package org.apache.hadoop.hbase.http
Copied from hadoop source code.
See https://issues.apache.org/jira/browse/HADOOP-10232 to know why.
org.apache.hadoop.hbase.http.conf - package org.apache.hadoop.hbase.http.conf
 
org.apache.hadoop.hbase.http.jmx - package org.apache.hadoop.hbase.http.jmx
This package provides access to JMX primarily through the JMXJsonServlet class.
org.apache.hadoop.hbase.http.lib - package org.apache.hadoop.hbase.http.lib
This package provides user-selectable (via configuration) classes that add functionality to the web UI.
org.apache.hadoop.hbase.http.log - package org.apache.hadoop.hbase.http.log
 
org.apache.hadoop.hbase.io - package org.apache.hadoop.hbase.io
 
org.apache.hadoop.hbase.io.compress - package org.apache.hadoop.hbase.io.compress
 
org.apache.hadoop.hbase.io.crypto - package org.apache.hadoop.hbase.io.crypto
 
org.apache.hadoop.hbase.io.crypto.aes - package org.apache.hadoop.hbase.io.crypto.aes
 
org.apache.hadoop.hbase.io.encoding - package org.apache.hadoop.hbase.io.encoding
 
org.apache.hadoop.hbase.io.hadoopbackport - package org.apache.hadoop.hbase.io.hadoopbackport
 
org.apache.hadoop.hbase.io.hfile - package org.apache.hadoop.hbase.io.hfile
Provides implementations of HFile and HFile BlockCache.
org.apache.hadoop.hbase.io.hfile.bucket - package org.apache.hadoop.hbase.io.hfile.bucket
Provides BucketCache, an implementation of BlockCache.
org.apache.hadoop.hbase.io.util - package org.apache.hadoop.hbase.io.util
 
org.apache.hadoop.hbase.ipc - package org.apache.hadoop.hbase.ipc
Tools to help define network clients and servers.
org.apache.hadoop.hbase.jetty - package org.apache.hadoop.hbase.jetty
 
org.apache.hadoop.hbase.mapred - package org.apache.hadoop.hbase.mapred
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
org.apache.hadoop.hbase.mapreduce - package org.apache.hadoop.hbase.mapreduce
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
org.apache.hadoop.hbase.mapreduce.replication - package org.apache.hadoop.hbase.mapreduce.replication
 
org.apache.hadoop.hbase.master - package org.apache.hadoop.hbase.master
 
org.apache.hadoop.hbase.master.balancer - package org.apache.hadoop.hbase.master.balancer
 
org.apache.hadoop.hbase.master.cleaner - package org.apache.hadoop.hbase.master.cleaner
 
org.apache.hadoop.hbase.master.handler - package org.apache.hadoop.hbase.master.handler
 
org.apache.hadoop.hbase.master.normalizer - package org.apache.hadoop.hbase.master.normalizer
 
org.apache.hadoop.hbase.master.procedure - package org.apache.hadoop.hbase.master.procedure
 
org.apache.hadoop.hbase.master.snapshot - package org.apache.hadoop.hbase.master.snapshot
 
org.apache.hadoop.hbase.metrics - package org.apache.hadoop.hbase.metrics
Metrics API for HBase.
org.apache.hadoop.hbase.metrics.impl - package org.apache.hadoop.hbase.metrics.impl
Implementation of the HBase Metrics framework.
org.apache.hadoop.hbase.migration - package org.apache.hadoop.hbase.migration
 
org.apache.hadoop.hbase.monitoring - package org.apache.hadoop.hbase.monitoring
 
org.apache.hadoop.hbase.namespace - package org.apache.hadoop.hbase.namespace
 
org.apache.hadoop.hbase.net - package org.apache.hadoop.hbase.net
 
org.apache.hadoop.hbase.procedure - package org.apache.hadoop.hbase.procedure
 
org.apache.hadoop.hbase.procedure.flush - package org.apache.hadoop.hbase.procedure.flush
 
org.apache.hadoop.hbase.procedure2 - package org.apache.hadoop.hbase.procedure2
 
org.apache.hadoop.hbase.procedure2.store - package org.apache.hadoop.hbase.procedure2.store
 
org.apache.hadoop.hbase.procedure2.store.wal - package org.apache.hadoop.hbase.procedure2.store.wal
 
org.apache.hadoop.hbase.procedure2.util - package org.apache.hadoop.hbase.procedure2.util
 
org.apache.hadoop.hbase.protobuf - package org.apache.hadoop.hbase.protobuf
Holds classes generated from protobuf src/main/protobuf definition files.
org.apache.hadoop.hbase.quotas - package org.apache.hadoop.hbase.quotas
 
org.apache.hadoop.hbase.regionserver - package org.apache.hadoop.hbase.regionserver
 
org.apache.hadoop.hbase.regionserver.compactions - package org.apache.hadoop.hbase.regionserver.compactions
 
org.apache.hadoop.hbase.regionserver.handler - package org.apache.hadoop.hbase.regionserver.handler
 
org.apache.hadoop.hbase.regionserver.querymatcher - package org.apache.hadoop.hbase.regionserver.querymatcher
 
org.apache.hadoop.hbase.regionserver.snapshot - package org.apache.hadoop.hbase.regionserver.snapshot
 
org.apache.hadoop.hbase.regionserver.throttle - package org.apache.hadoop.hbase.regionserver.throttle
 
org.apache.hadoop.hbase.regionserver.wal - package org.apache.hadoop.hbase.regionserver.wal
 
org.apache.hadoop.hbase.replication - package org.apache.hadoop.hbase.replication
Multi Cluster Replication
org.apache.hadoop.hbase.replication.master - package org.apache.hadoop.hbase.replication.master
 
org.apache.hadoop.hbase.replication.regionserver - package org.apache.hadoop.hbase.replication.regionserver
 
org.apache.hadoop.hbase.rest - package org.apache.hadoop.hbase.rest
HBase REST
org.apache.hadoop.hbase.rest.client - package org.apache.hadoop.hbase.rest.client
 
org.apache.hadoop.hbase.rest.filter - package org.apache.hadoop.hbase.rest.filter
 
org.apache.hadoop.hbase.rest.model - package org.apache.hadoop.hbase.rest.model
 
org.apache.hadoop.hbase.rest.protobuf.generated - package org.apache.hadoop.hbase.rest.protobuf.generated
 
org.apache.hadoop.hbase.rest.provider - package org.apache.hadoop.hbase.rest.provider
 
org.apache.hadoop.hbase.rest.provider.consumer - package org.apache.hadoop.hbase.rest.provider.consumer
 
org.apache.hadoop.hbase.rest.provider.producer - package org.apache.hadoop.hbase.rest.provider.producer
 
org.apache.hadoop.hbase.rsgroup - package org.apache.hadoop.hbase.rsgroup
 
org.apache.hadoop.hbase.security - package org.apache.hadoop.hbase.security
 
org.apache.hadoop.hbase.security.access - package org.apache.hadoop.hbase.security.access
 
org.apache.hadoop.hbase.security.token - package org.apache.hadoop.hbase.security.token
 
org.apache.hadoop.hbase.security.visibility - package org.apache.hadoop.hbase.security.visibility
 
org.apache.hadoop.hbase.security.visibility.expression - package org.apache.hadoop.hbase.security.visibility.expression
 
org.apache.hadoop.hbase.snapshot - package org.apache.hadoop.hbase.snapshot
 
org.apache.hadoop.hbase.thrift - package org.apache.hadoop.hbase.thrift
Provides an HBase Thrift service.
org.apache.hadoop.hbase.thrift.generated - package org.apache.hadoop.hbase.thrift.generated
 
org.apache.hadoop.hbase.thrift2 - package org.apache.hadoop.hbase.thrift2
Provides an HBase Thrift service.
org.apache.hadoop.hbase.thrift2.generated - package org.apache.hadoop.hbase.thrift2.generated
 
org.apache.hadoop.hbase.tmpl.common - package org.apache.hadoop.hbase.tmpl.common
 
org.apache.hadoop.hbase.tmpl.master - package org.apache.hadoop.hbase.tmpl.master
 
org.apache.hadoop.hbase.tmpl.regionserver - package org.apache.hadoop.hbase.tmpl.regionserver
 
org.apache.hadoop.hbase.tool - package org.apache.hadoop.hbase.tool
 
org.apache.hadoop.hbase.trace - package org.apache.hadoop.hbase.trace
 
org.apache.hadoop.hbase.types - package org.apache.hadoop.hbase.types
This package provides the definition and implementation of HBase's extensible data type API.
org.apache.hadoop.hbase.util - package org.apache.hadoop.hbase.util
 
org.apache.hadoop.hbase.util.byterange - package org.apache.hadoop.hbase.util.byterange
 
org.apache.hadoop.hbase.util.byterange.impl - package org.apache.hadoop.hbase.util.byterange.impl
 
org.apache.hadoop.hbase.util.hbck - package org.apache.hadoop.hbase.util.hbck
 
org.apache.hadoop.hbase.util.vint - package org.apache.hadoop.hbase.util.vint
 
org.apache.hadoop.hbase.wal - package org.apache.hadoop.hbase.wal
 
org.apache.hadoop.hbase.zookeeper - package org.apache.hadoop.hbase.zookeeper
 
org.apache.hadoop.hbase.zookeeper.lock - package org.apache.hadoop.hbase.zookeeper.lock
 
org.apache.hadoop.metrics2 - package org.apache.hadoop.metrics2
 
org.apache.hadoop.metrics2.impl - package org.apache.hadoop.metrics2.impl
 
org.apache.hadoop.metrics2.lib - package org.apache.hadoop.metrics2.lib
 
org.apache.hadoop.metrics2.util - package org.apache.hadoop.metrics2.util
 
org.apache.hbase.archetypes.exemplars.client - package org.apache.hbase.archetypes.exemplars.client
This package provides fully-functional exemplar Java code demonstrating simple usage of the hbase-client API, for incorporation into a Maven archetype with hbase-client dependency.
org.apache.hbase.archetypes.exemplars.shaded_client - package org.apache.hbase.archetypes.exemplars.shaded_client
This package provides fully-functional exemplar Java code demonstrating simple usage of the hbase-client API, for incorporation into a Maven archetype with hbase-shaded-client dependency.
ostream - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
OSVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
oswrite(KeyValue, OutputStream) - Static method in class org.apache.hadoop.hbase.KeyValue
oswrite(KeyValue, OutputStream, boolean) - Static method in class org.apache.hadoop.hbase.KeyValue
Write out a KeyValue in the manner in which we used to when KeyValue was a Writable but do not require a DataOutput, just take plain OutputStream Named oswrite so does not clash with KeyValue.write(KeyValue, DataOutput)
oswrite(Cell, OutputStream, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
ourClusterKey - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The cluster key of the local cluster
out - Variable in class org.apache.hadoop.hbase.codec.BaseEncoder
 
outOfOrderException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
Different types of exceptions
outOfOrderException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
OutOfOrderScannerNextException - Exception in org.apache.hadoop.hbase.exceptions
Thrown by a RegionServer while doing next() calls on a ResultScanner.
OutOfOrderScannerNextException() - Constructor for exception org.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextException
 
OutOfOrderScannerNextException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextException
 
output - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
OUTPUT_CONF_PREFIX - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Prefix for configuration property overrides to apply in TableOutputFormat.setConf(Configuration).
OUTPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapred.TableOutputFormat
JobConf parameter that specifies the output table
OUTPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Job parameter that specifies the output table.
outputArrayOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
outputStream - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
outputStream - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
FileSystem stream to write into.
outputStreamFromByteRange(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.types.PBType
Create a CodedOutputStream from a PositionedByteRange.
overlappingKeys(byte[], byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Returns true if the first range start1...end1 overlaps with the second range start2...end2, assuming the byte arrays represent row keys
overwriteRegions(Connection, List<HRegionInfo>, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Overwrites the specified regions from hbase:meta
OWNER - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
OWNER_KEY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
ownerToString() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 

P

P - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'P'
PackageMarker - Annotation Type in org.apache.hadoop.hbase.metrics
This is a dummy annotation that forces javac to produce output for otherwise empty package-info.java.
PackagePrivateFieldAccessor - Class in org.apache.hadoop.hbase.client
A helper class used to access the package private field in o.a.h.h.client package.
PackagePrivateFieldAccessor() - Constructor for class org.apache.hadoop.hbase.client.PackagePrivateFieldAccessor
 
padFront(String, char, int) - Static method in class org.apache.hadoop.hbase.util.Strings
Push the input string to the right by appending a character before it, usually a space.
padHead(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
padTail(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
pageDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
 
pageDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
 
pageDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
 
pageDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
PageFilter - Class in org.apache.hadoop.hbase.filter
Implementation of Filter interface that limits results to a specific page size.
PageFilter(long) - Constructor for class org.apache.hadoop.hbase.filter.PageFilter
Constructor that takes a maximum page size.
pageUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
 
pageUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
 
pageUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
 
pageUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
Paging - Class in org.apache.hadoop.hbase.hbtop.screen.top
Utility class for paging for the metrics.
Paging() - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.Paging
 
Pair<T1,T2> - Class in org.apache.hadoop.hbase.util
A generic class for pairs.
Pair() - Constructor for class org.apache.hadoop.hbase.util.Pair
Default constructor.
Pair(T1, T2) - Constructor for class org.apache.hadoop.hbase.util.Pair
Constructor
PairOfSameType<T> - Class in org.apache.hadoop.hbase.util
A generic, immutable class for pairs of objects both of type T.
PairOfSameType(T, T) - Constructor for class org.apache.hadoop.hbase.util.PairOfSameType
Constructor
parallelSeekEnabled - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
A flag that enables StoreFileScanner parallel-seeking
ParallelSeekHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handler to seek storefiles in parallel.
ParallelSeekHandler(KeyValueScanner, Cell, long, CountDownLatch) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
 
param - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
params - Variable in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
 
parent - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
Tree content/structure used during tokenization
parent - Variable in class org.apache.hadoop.hbase.util.ClassLoaderBase
Parent class loader.
parentLockNode - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
 
parentStartPosition - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
parentStartPosition - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
 
parse(String, boolean) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
 
parse(String, List<Field>, boolean) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
 
parse(byte[], int, int) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
 
parse(byte[], int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
parse(String) - Method in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
 
parse(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
 
parse(Configuration) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperMainServer
 
parseCell() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
Extract a Cell.
parseCell() - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueDecoder
 
parseCell() - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueDecoder
 
parseColumn(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
Splits a column in family:qualifier form into separate byte arrays.
parseComparator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Splits a column in comparatorType:comparatorValue form into separate byte arrays
ParseConstants - Class in org.apache.hadoop.hbase.filter
ParseConstants holds a bunch of constants related to parsing Filter Strings Used by ParseFilter
ParseConstants() - Constructor for class org.apache.hadoop.hbase.filter.ParseConstants
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
parseDelimitedFrom(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Parses all the HRegionInfo instances from the passed in stream until EOF.
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
ParseException - Exception in org.apache.hadoop.hbase.security.visibility
 
ParseException() - Constructor for exception org.apache.hadoop.hbase.security.visibility.ParseException
 
ParseException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.ParseException
 
ParseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.security.visibility.ParseException
 
ParseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.security.visibility.ParseException
 
ParseFilter - Class in org.apache.hadoop.hbase.filter
This class allows a user to specify a filter via a string The string is parsed using the methods of this class and a filter object is constructed.
ParseFilter() - Constructor for class org.apache.hadoop.hbase.filter.ParseFilter
 
parseFilterString(String) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Parses the filterString and constructs a filter using it
parseFilterString(byte[]) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Parses the filterString and constructs a filter using it
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.ClusterId
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BitComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.Filter
Concrete implementers can signal a failure condition in their code by throwing an IOException.
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FilterList
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.LongComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.NullComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RegexStringComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SkipFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
parseFrom(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
parseFrom(DataInputStream) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Parses an HRegionInfo instance from the passed in stream.
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.RegionTransition
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.ServerName
Get a ServerName from the passed in data bytes.
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.SplitLogTask
 
parseFromOrNull(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
parseFromOrNull(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
 
parseFromProtoRequest(AdminProtos.CloseRegionRequest) - Method in interface org.apache.hadoop.hbase.coordination.CloseRegionCoordination
Construct CloseRegionDetails instance from CloseRegionRequest.
parseFromProtoRequest(AdminProtos.OpenRegionRequest.RegionOpenInfo) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
Construct OpenRegionDetails instance from part of protobuf request.
parseFromProtoRequest(AdminProtos.CloseRegionRequest) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination
Parse ZK-related fields from request.
parseFromProtoRequest(AdminProtos.OpenRegionRequest.RegionOpenInfo) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
Parse ZK-related fields from request.
parseHashType(String) - Static method in class org.apache.hadoop.hbase.util.Hash
This utility method converts String representation of hash function name to a symbolic constant.
parseHostname(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
parseHostname(String) - Static method in class org.apache.hadoop.hbase.util.Addressing
 
parseInt(String, int, int) - Static method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
parseLastFlushedSequenceIdFrom(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
parseLong(String, long, long) - Static method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
Parse a number and enforce a range.
parseNamespaceResult(Result, QuotaTableUtil.NamespaceQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseNamespaceResult(String, Result, QuotaTableUtil.NamespaceQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseOptions(String[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
 
parsePeerFrom(byte[]) - Static method in class org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
 
parsePort(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
parsePort(String) - Static method in class org.apache.hadoop.hbase.util.Addressing
 
PARSER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
PARSER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
PARSER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
PARSER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
parser - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
PARSER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
parseRegionInfoFromRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Returns an HRI parsed from this regionName.
parseRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Separate elements of a regionName.
parseRegionStoreSequenceIds(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
parseResult(Result, QuotaTableUtil.QuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseRowKey(byte[], int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
Return starting position and length of row key from the specified line bytes.
parseServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
parseSimpleFilterExpression(byte[]) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Constructs a filter object given a simple filter expression
parseStartcode(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
parseTableCFs(byte[]) - Static method in class org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
Parse bytes into TableCFs.
parseTableCFsFromConfig(String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
parseTableCFsFromConfig(String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
Convert tableCFs string into Map.
parseTableResult(Result, QuotaTableUtil.TableQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseTableResult(TableName, Result, QuotaTableUtil.TableQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseUserResult(Result, QuotaTableUtil.UserQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseUserResult(String, Result, QuotaTableUtil.UserQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
parseVersionedServerName(byte[]) - Static method in class org.apache.hadoop.hbase.ServerName
Use this method instantiating a ServerName from bytes gotten from a call to ServerName.getVersionedBytes().
parseWALPositionFrom(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
parseZooCfg(Configuration, InputStream) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
Deprecated.
in 0.96 onwards. HBase will no longer rely on zoo.cfg availability.
partiallyMatchesToken(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
byte[] utils
passedPrefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
 
passesDeleteFamilyBloomFilter(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
passesGeneralBloomFilter(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
A method for checking Bloom filters.
passesKeyRangeFilter(Scan) - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
 
passesKeyRangeFilter(Scan) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
Checks whether the given scan rowkey range overlaps with the current storefile's
PASSWORD - Static variable in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
 
password - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
PASSWORDFILE - Static variable in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
 
passwordFile - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
path - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Path of file
path - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
May be null if we were passed a stream.
path - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
path - Variable in class org.apache.hadoop.hbase.regionserver.handler.FinishRegionRecoveringHandler
 
path - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
path - Static variable in class org.apache.hadoop.hbase.util.CompressionTest
 
pathPrefix - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
pattern - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
 
pause(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
PAUSE_TIME_WITH_GC_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
 
PAUSE_TIME_WITH_GC_KEY - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
 
PAUSE_TIME_WITHOUT_GC_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
 
PAUSE_TIME_WITHOUT_GC_KEY - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
 
PayloadCarryingServerCallable<T> - Class in org.apache.hadoop.hbase.client
This class is used to unify HTable calls with AsyncProcess Framework.
PayloadCarryingServerCallable(Connection, TableName, byte[], RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.client.PayloadCarryingServerCallable
 
PayloadCarryingServerCallable(Connection, TableName, byte[], RpcControllerFactory, int) - Constructor for class org.apache.hadoop.hbase.client.PayloadCarryingServerCallable
 
PB_MAGIC - Static variable in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Magic we put ahead of a serialized protobuf message.
PB_WAL_COMPLETE_MAGIC - Static variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
PB_WAL_MAGIC - Static variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
PBCell - Class in org.apache.hadoop.hbase.types
An example for using protobuf objects with DataType API.
PBCell() - Constructor for class org.apache.hadoop.hbase.types.PBCell
 
pbkdf128(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return a 128 bit key derived from the concatenation of the supplied arguments using PBKDF2WithHmacSHA1 at 10,000 iterations.
pbkdf128(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return a 128 bit key derived from the concatenation of the supplied arguments using PBKDF2WithHmacSHA1 at 10,000 iterations.
PBType<T extends com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.types
A base-class for DataType implementations backed by protobuf.
PBType() - Constructor for class org.apache.hadoop.hbase.types.PBType
 
PBUF_TRAILER_MINOR_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
HFile minor version that introduced pbuf filetrailer
peek() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
peek() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
 
peek() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
peek() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Look at the next Cell in this scanner, but do not iterate scanner.
peek() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
peek() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
peek() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
peek() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
peek() - Method in class org.apache.hadoop.hbase.util.BoundedArrayQueue
 
peek() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
peek() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
peek() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Retrieve the next byte from this range without incrementing position.
peerAdded(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
peerAdded(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
 
peerAdded(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
peerConfigUpdated(ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
 
peerConfigUpdated(ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigListener
Callback method for when users update the ReplicationPeerConfig for this peer
peerConfigUpdated(ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
peerExists(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
peerListChanged(List<String>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
 
peerListChanged(List<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationListener
The list of registered peer clusters has changed.
peerRemoved(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
 
peerRemoved(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationListener
A peer cluster has been removed (i.e.
peerRemoved(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
 
peerRemoved(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
peerStateNodeName - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the znode that contains the replication status of a remote slave (i.e.
peersZNode - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the znode that contains a list of all remote slave (i.e.
pendingFirstType - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
fields
PER_BLOCK_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
PERCENT_FILES_LOCAL - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
PERCENT_FILES_LOCAL_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
PERCENT_FILES_LOCAL_SECONDARY_REGIONS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
PERCENT_FILES_LOCAL_SECONDARY_REGIONS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
PerClientRandomNonceGenerator - Class in org.apache.hadoop.hbase.client
NonceGenerator implementation that uses client ID hash + random int as nonce group, and random numbers as nonces.
PerClientRandomNonceGenerator() - Constructor for class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
 
performCompaction(InternalScanner, Compactor.CellSink, long, boolean, ThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
Performs the compaction.
PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
PERIODIC_ROLL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
periodicExecute(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureInMemoryChore
 
periodicRollForTesting() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
Permission - Class in org.apache.hadoop.hbase.security.access
Base permissions instance representing the ability to perform a given set of actions.
Permission() - Constructor for class org.apache.hadoop.hbase.security.access.Permission
Empty constructor for Writable implementation.
Permission(Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.Permission
 
Permission(byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.Permission
 
Permission.Action - Enum in org.apache.hadoop.hbase.security.access
 
PersistentIOEngine - Interface in org.apache.hadoop.hbase.io.hfile.bucket
A class implementing PersistentIOEngine interface supports persistent and file integrity verify for BucketCache
PHOENIX - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
 
PING_CALL_ID - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
placeSecondaryAndTertiaryWithRestrictions(Map<HRegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
For regions that share the primary, avoid placing the secondary and tertiary on a same RS.
PlainTextMessageBodyProducer - Class in org.apache.hadoop.hbase.rest.provider.producer
An adapter between Jersey and Object.toString().
PlainTextMessageBodyProducer() - Constructor for class org.apache.hadoop.hbase.rest.provider.producer.PlainTextMessageBodyProducer
 
PleaseHoldException - Exception in org.apache.hadoop.hbase
This exception is thrown by the master when a region server was shut down and restarted so fast that the master still hasn't processed the server shutdown of the first instance, or when master is initializing and client call admin operations, or when an operation is performed on a region server that is still starting.
PleaseHoldException(String) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
 
PleaseHoldException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
 
PleaseHoldException(Throwable) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
 
pluralize(Collection<?>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
pluralize(int) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
plus(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
Poll for the first completed task whether it is a success or execution exception.
poll() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
 
poll() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
 
poll() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
poll() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
poll() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
Fetch one Procedure from the queue
poll() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
 
poll() - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
 
poll() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
poll() - Method in class org.apache.hadoop.hbase.util.BoundedArrayQueue
 
poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.util.BoundedCompletionService
 
poll() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.util.StealJobQueue
 
pollFirst() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
pollFirstEntry() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
pollForFirstSuccessfullyCompletedTask(long, TimeUnit, int, int) - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
Poll for the first successfully completed task whose completed order is in startIndex, endIndex(exclusive) range
pollKeyPress() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
pollKeyPress() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
 
pollLast() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
 
pollLast() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
 
pollLast() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
pollLastEntry() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
pollRealKV() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Fetches the top sub-scanner from the priority queue, ensuring that a real seek has been done on it.
pool(ExecutorService) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Override the default executor pool defined by the hbase.htable.threads.* configuration values.
pool - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
pool - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
pool - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.ArraySearcherPool
 
PoolMap<K,V> - Class in org.apache.hadoop.hbase.util
The PoolMap maps a key to a collection of values, the elements of which are managed by a pool.
PoolMap(PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.util.PoolMap
 
PoolMap(PoolMap.PoolType, int) - Constructor for class org.apache.hadoop.hbase.util.PoolMap
 
PoolMap.Pool<R> - Interface in org.apache.hadoop.hbase.util
 
PoolMap.PoolType - Enum in org.apache.hadoop.hbase.util
 
PoolMap.ReusablePool<R> - Class in org.apache.hadoop.hbase.util
The ReusablePool represents a PoolMap.Pool that builds on the LinkedList class.
PoolMap.ReusablePool(int) - Constructor for class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
 
popArguments(Stack<ByteBuffer>, Stack<Filter>) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Pops an argument from the operator stack and the number of arguments required by the operator from the filterStack and evaluates them
popFromRowBuffer(RowNodeReader) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
populateBuffer(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
methods
populateFamily() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
populateFirstNonRowFields() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
populateLastNonRowFields() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
populateMvccVersion() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
populateNonRowFields(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
populateNonRowFieldsAndCompareTo(int, Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
fill in family/qualifier/ts/type/value
populatePool(ExecutorService) - Method in class org.apache.hadoop.hbase.master.BulkAssigner
 
populatePool(ExecutorService) - Method in class org.apache.hadoop.hbase.master.BulkReOpen
Unassign all regions, so that they go through the regular region assignment flow (in assignment manager) and are re-opened.
populatePool(ExecutorService) - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
 
populatePreviousNonRowFields() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
populatePut(byte[], ImportTsv.TsvParser.ParsedLine, Put, int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
populateQualifier() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
populateTag() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
populateTimestamp() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
populateType() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
populateValueOffsets() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
port - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
port - Static variable in class org.apache.hadoop.hbase.thrift.DemoClient
 
port - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
port - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
 
port - Variable in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
position - Variable in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
The current index into the range.
positionAfterLastCell() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
The content of the buffers doesn't matter here, only that afterLast=true and beforeFirst=false
positionAfterLastCell() - Method in interface org.apache.hadoop.hbase.codec.prefixtree.scanner.CellSearcher
Note: This may not be appropriate to have in the interface.
positionAt(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
methods
positionAt(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
CellSearcher methods
positionAt(Cell) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.scanner.CellSearcher
Do everything within this scanner's power to find the key.
positionAtFirstCell() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
advance
positionAtLastCell() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayReversibleScanner
 
positionAtLastRow() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayReversibleScanner
 
positionAtOrAfter(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
Identical workflow as positionAtOrBefore, but split them to avoid having ~10 extra if-statements.
positionAtOrAfter(Cell) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.scanner.CellSearcher
Same as positionAt(..), but go to the extra effort of finding the next key if there's no exact match.
positionAtOrBefore(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
 
positionAtOrBefore(Cell) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.scanner.CellSearcher
Same as positionAt(..), but go to the extra effort of finding the previous key if there's no exact match.
positionAtQualifierTimestamp(Cell, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
 
PositionedByteRange - Interface in org.apache.hadoop.hbase.util
Extends ByteRange with additional methods to support tracking a consumers position within the viewport.
positionToByteArray(long) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
positiveJitterRate() - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
 
post(String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a POST request
post(String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a POST request
post(Cluster, String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a POST request
post(Cluster, String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a POST request
post(String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a POST request
post(Cluster, String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a POST request
post(NamespacesInstanceModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
Build a response for POST create namespace with properties specified.
post(CellSetModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
 
post(ScannerModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerResource
 
post(TableSchemaModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
 
postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after a abortProcedure request has been processed.
postAbortProcedure() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the new column family has been created.
postAddColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the new column family has been created.
postAddColumnHandler(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postAddRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postAddRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postAddRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after a new region server group is added
postAddRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postAddRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postAppend(ObserverContext<RegionCoprocessorEnvironment>, Append, Result) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postAppend(ObserverContext<RegionCoprocessorEnvironment>, Append, Result) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after Append
postAppend(Append, Result) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postAppend(long, long, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
 
postAppend(long, long, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
 
postAppend(long, long, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
For notification post append to the writer.
postAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the region assignment has been requested.
postAssign(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postBalance(ObserverContext<MasterCoprocessorEnvironment>, List<RegionPlan>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postBalance(ObserverContext<MasterCoprocessorEnvironment>, List<RegionPlan>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postBalance(ObserverContext<MasterCoprocessorEnvironment>, List<RegionPlan>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the balancing plan has been submitted.
postBalance(List<RegionPlan>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postBalance(ObserverContext<MasterCoprocessorEnvironment>, List<RegionPlan>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after a region server group is removed
postBalanceRSGroup(String, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String, boolean) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the flag to enable/disable balancing has changed.
postBalanceSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
This will be called after applying a batch of Mutations on a region.
postBatchMutate(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
 
postBatchMutate(MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postBatchMutate(HRegion) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
The hook to be executed after the process() and applying the Mutations to region.
postBatchMutateIndispensably(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postBatchMutateIndispensably(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the completion of batch put/delete and will be called even if the batch operation fails
postBatchMutateIndispensably(MiniBatchOperationInProgress<Mutation>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postBinary(byte[], UriInfo, HttpHeaders) - Method in class org.apache.hadoop.hbase.rest.RowResource
 
postBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment>, List<Pair<byte[], String>>, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment>, List<Pair<byte[], String>>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after bulkLoadHFile.
postBulkLoadHFile(List<Pair<byte[], String>>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after checkAndDelete
postCheckAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after checkAndPut
postCheckAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>, List<ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>, List<ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>, List<ServerName>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after clear dead region servers.
postClearDeadServers(List<ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>, List<ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>, List<ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after a snapshot clone operation has been requested.
postCloneSnapshot(HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postClose(ObserverContext<RegionCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postClose(ObserverContext<RegionCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the region is reported as closed to the master.
postClose(boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked after a region is closed
postCloseRegionOperation(ObserverContext<RegionCoprocessorEnvironment>, Region.Operation) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postCloseRegionOperation(ObserverContext<RegionCoprocessorEnvironment>, Region.Operation) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after releasing read lock in Region.closeRegionOperation().
postCloseRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postCommitStoreFile(ObserverContext<RegionCoprocessorEnvironment>, byte[], Path, Path) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postCommitStoreFile(ObserverContext<RegionCoprocessorEnvironment>, byte[], Path, Path) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after moving bulk loaded hfile to region directory.
postCommitStoreFile(byte[], Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after compaction has completed and the new store file has been moved in to place.
postCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
postCompact(Store, StoreFile, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Called after the store compaction has completed.
postCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, ImmutableList<StoreFile>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, ImmutableList<StoreFile>, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, ImmutableList<StoreFile>, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the StoreFiles to compact have been selected from the available candidates.
postCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, ImmutableList<StoreFile>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
postCompactSelection(Store, ImmutableList<StoreFile>, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Called after the StoreFiles to be compacted have been selected from the available candidates.
postCompleteSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postCompleteSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after any split request is processed.
postCompleteSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked after a split is completed irrespective of a failure or success.
postCreateCoprocScanner(CompactionRequest, ScanType, InternalScanner, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
Calls coprocessor, if any, to create scanners - after normal scanner creation.
postCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the createNamespace operation has been requested.
postCreateNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment>, ReplicationEndpoint) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment>, ReplicationEndpoint) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
This will be called after the replication endpoint is instantiated.
postCreateReplicationEndPoint(ReplicationEndpoint) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment>, ReplicationEndpoint) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment>, ReplicationEndpoint) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController.VisibilityReplication
 
postCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
 
postCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the createTable operation has been requested.
postCreateTable(HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the createTable operation has been requested.
postCreateTableHandler(HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the client deletes a value.
postDelete(Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the column family has been deleted.
postDeleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the column family has been deleted.
postDeleteColumnHandler(TableName, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the deleteNamespace operation has been requested.
postDeleteNamespace(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the delete snapshot operation has been requested.
postDeleteSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the deleteTable operation has been requested.
postDeleteTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after HMaster deletes a table.
postDeleteTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postDisable(MasterProcedureEnv, MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
Action after disabling table.
postDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the disableTable operation has been requested.
postDisableTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the disableTable operation has been requested.
postDisableTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postDispatchMerge(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postDispatchMerge(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDispatchMerge(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
called after dispatching the region merge request.
postDispatchMerge(HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDispatchMerge(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the enableTable operation has been requested.
postEnableTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the enableTable operation has been requested.
postEnableTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postEncoding(HFileBlockEncodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder
 
postEncoding(BlockType) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
postEncoding(BlockType) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
Do any action that needs to be performed after the encoding.
postEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment>, Service, String, Message, Message.Builder) - Method in interface org.apache.hadoop.hbase.coprocessor.EndpointObserver
Called after an Endpoint service method is invoked.
postEndpointInvocation(Service, String, Message, Message.Builder) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment>, Service, String, Message, Message.Builder) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postExists(ObserverContext<RegionCoprocessorEnvironment>, Get, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postExists(ObserverContext<RegionCoprocessorEnvironment>, Get, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the client tests for existence using a Get.
postExists(Get, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postFlush(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postFlush(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postFlush(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
postFlush(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after a Store's memstore is flushed to disk.
postFlush() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked after a memstore flush
postFlush(Store, StoreFile) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked after a memstore flush
postGet(Get, List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], Result) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], Result) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after a client makes a GetClosestRowBefore request.
postGetClosestRowBefore(byte[], byte[], Result) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postGetClusterStatus(ObserverContext<MasterCoprocessorEnvironment>, ClusterStatus) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postGetClusterStatus(ObserverContext<MasterCoprocessorEnvironment>, ClusterStatus) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postGetClusterStatus(ObserverContext<MasterCoprocessorEnvironment>, ClusterStatus) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after get cluster status.
postGetClusterStatus(ClusterStatus) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postGetClusterStatus(ObserverContext<MasterCoprocessorEnvironment>, ClusterStatus) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after a getNamespaceDescriptor request has been processed.
postGetNamespaceDescriptor(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics
 
postGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the client performs a Get
postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Deprecated.
Use postGetTableDescriptors with regex instead.
postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after a getTableDescriptors request has been processed.
postGetTableDescriptors(List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
Deprecated.
postGetTableDescriptors(List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after a getTableNames request has been processed.
postGetTableNames(List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment, Result) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment, Result) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after increment
postIncrement(Increment, Result) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postIncrementColumnValue(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], long, boolean, long) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postIncrementColumnValue(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], long, boolean, long) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Deprecated.
This hook is no longer called by the RegionServer
postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment>, DeleteTracker) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment>, DeleteTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the ScanQueryMatcher creates ScanDeleteTracker.
postInstantiateDeleteTracker(DeleteTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment>, DeleteTracker) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after a listNamespaceDescriptors request has been processed.
postListNamespaceDescriptors(List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postListProcedures(ObserverContext<MasterCoprocessorEnvironment>, List<ProcedureInfo>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postListProcedures(ObserverContext<MasterCoprocessorEnvironment>, List<ProcedureInfo>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postListProcedures(ObserverContext<MasterCoprocessorEnvironment>, List<ProcedureInfo>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after a listProcedures request has been processed.
postListProcedures(List<ProcedureInfo>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postListProcedures(ObserverContext<MasterCoprocessorEnvironment>, List<ProcedureInfo>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postListProcedures(ObserverContext<MasterCoprocessorEnvironment>, List<ProcedureInfo>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after listSnapshots request has been processed.
postListSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postLogArchive(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
 
postLogArchive(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
The WAL has been archived.
postLogReplay(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postLogReplay(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the log replay on the region is over.
postLogReplay() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked after log replay on region
postLogReplay(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postLogReplay(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
postLogRoll(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
 
postLogRoll(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
The WAL has been rolled.
postLogRoll(Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
postMasterStartupInitialize() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
postMasterStartupInitialize() - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
If balancer needs to do initialization after Master has started up, lets do that here.
postMasterStartupInitialize() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
postMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, Region) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
postMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, Region) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
called after the regions merge.
postMerge(HRegion, HRegion, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
postMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, Region) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, Region) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, Region) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
This will be called after PONR step as part of regions merge transaction.
postMergeCommit(HRegion, HRegion, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, Region) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the column family has been updated.
postModifyColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the column family has been updated.
postModifyColumnHandler(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the modifyNamespace operation has been requested.
postModifyNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the modifyTable operation has been requested.
postModifyTable(TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after to modifying a table's properties.
postModifyTableHandler(TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the region move has been requested.
postMove(HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postMoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postMoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postMoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after servers are moved to target region server group
postMoveServers(Set<Address>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postMoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after servers are moved to target region server group
postMoveServersAndTables(Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postMoveTables(ObserverContext<MasterCoprocessorEnvironment>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postMoveTables(ObserverContext<MasterCoprocessorEnvironment>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postMoveTables(ObserverContext<MasterCoprocessorEnvironment>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after servers are moved to target region server group
postMoveTables(Set<TableName>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postMoveTables(ObserverContext<MasterCoprocessorEnvironment>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, RegionObserver.MutationType, Mutation, Cell, Cell) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, RegionObserver.MutationType, Mutation, Cell, Cell) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after a new cell has been created during an increment operation, but before it is committed to the WAL or memstore.
postMutationBeforeWAL(RegionObserver.MutationType, Mutation, Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, RegionObserver.MutationType, Mutation, Cell, Cell) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, RegionObserver.MutationType, Mutation, Cell, Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
postNoBody(byte[], UriInfo, HttpHeaders) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
Build a response for POST create namespace with no properties specified.
postOpeartionFailure(IOException, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Called after the operation is terminated with a failure.
postOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the region is reported as open to the master.
postOpen() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked after a region open
postOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
Region related hooks
postOpenDeployTasks(Region) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
postOpenDeployTasks(RegionServerServices.PostOpenDeployContext) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
postOpenDeployTasks(RegionServerServices.PostOpenDeployContext) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
Tasks to perform after region open to complete deploy of region on regionserver
postOpenDeployTasks(Region) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
postOperationResult(V, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Called after the operation is completed and the result fetched.
postProcess(HRegion, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
 
postProcess(HRegion, WALEdit, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
The hook to be executed after process() and applying the Mutations to region.
postPut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postPut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the client stores a value.
postPut(Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postPut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the region has been marked offline.
postRegionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after a region server group is removed
postRemoveRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postRemoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postRemoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postRemoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after servers are removed from rsgroup
postRemoveServers(Set<Address>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postRemoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>, List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>, List<AdminProtos.WALEntry>, CellScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
This will be called after executing replication request to shipping log entries.
postReplicateLogEntries(List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>, List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after a snapshot restore operation has been requested.
postRestoreSnapshot(HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
This will be called after the roll back of the regions merge.
postRollBackMerge(HRegion, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postRollBackSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postRollBackSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
This will be called after the roll back of the split region is completed
postRollBackSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked just after the rollback of a failed split is done
postRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
postRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
This will be called after executing user request to roll a region server WAL.
postRollWALWriterRequest() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
postRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the client closes a scanner.
postScannerClose(InternalScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, byte[], int, short, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, byte[], int, short, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
This will be called by the scan flow when the current scanned row is being filtered out by the filter.
postScannerFilterRow(InternalScanner, byte[], int, short) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
This will be called by the scan flow when the current scanned row is being filtered out by the filter.
postScannerNext(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postScannerNext(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the client asks for the next row on a scanner.
postScannerNext(InternalScanner, List<Result>, int, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the client opens a new scanner.
postScannerOpen(Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
postSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the quota for the namespace is stored.
postSetNamespaceQuota(String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, Admin.MasterSwitchType) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after setting split / merge switch
postSetSplitOrMergeEnabled(boolean, Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the quota for the table is stored.
postSetTableQuota(TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the quota for the user is stored.
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the quota for the user on the specified table is stored.
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the quota for the user on the specified namespace is stored.
postSetUserQuota(String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postSetUserQuota(String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postSetUserQuota(String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the snapshot operation has been requested.
postSnapshot(HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postSnapshotOperation() - Method in class org.apache.hadoop.hbase.regionserver.HStore
Perform tasks needed after the completion of snapshot operation.
postSplit(ObserverContext<RegionCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postSplit(ObserverContext<RegionCoprocessorEnvironment>, Region, Region) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Deprecated.
Use postCompleteSplit() instead
postSplit(Region, Region) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked just after a split
postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called immediately after an active master instance has completed initialization.
postStartMaster() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
Master related hooks
postStartRegionOperation(ObserverContext<RegionCoprocessorEnvironment>, Region.Operation) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postStartRegionOperation(ObserverContext<RegionCoprocessorEnvironment>, Region.Operation) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
This will be called for region operations where read lock is acquired in Region.startRegionOperation().
postStartRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFile.Reader) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFile.Reader) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the creation of Reader for a store file.
postStoreFileReaderOpen(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFile.Reader) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postSync() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.MasterProcedureStoreListener
 
postSync() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureStoreListener
triggered when the store sync is completed.
postSync(long, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
 
postSync(long, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
 
postSync(long, int) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
For notification post writer sync.
postTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the table memstore is flushed to disk.
postTableFlush(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the truncateTable operation has been requested.
postTruncateTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after HMaster truncates a table.
postTruncateTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
postUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the region unassignment has been requested.
postUnassign(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
Implementers should override this version of the method and leave the deprecated one as-is.
postWALRestore(ObserverContext<RegionCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after a WALEdit replayed for this region.
postWALRestore(ObserverContext<RegionCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
postWALRestore(HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postWALRestore(HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
postWALRoll(ObserverContext<? extends WALCoprocessorEnvironment>, Path, Path) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
 
postWALRoll(ObserverContext<? extends WALCoprocessorEnvironment>, Path, Path) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
Called after rolling the current WAL
postWALRoll(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
Called after rolling the current WAL
postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
Implementers should override this method and leave the deprecated version as-is.
postWALWrite(ObserverContext<WALCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
 
postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
Called after a WALEdit is writen to WAL.
postWALWrite(ObserverContext<WALCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
postWALWrite(HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
 
preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>, ProcedureExecutor<MasterProcedureEnv>, long) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>, ProcedureExecutor<MasterProcedureEnv>, long) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>, ProcedureExecutor<MasterProcedureEnv>, long) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a abortProcedure request has been processed.
preAbortProcedure(ProcedureExecutor<MasterProcedureEnv>, long) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>, ProcedureExecutor<MasterProcedureEnv>, long) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>, ProcedureExecutor<MasterProcedureEnv>, long) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
pread - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to adding a new column family to the table.
preAddColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to adding a new column family to the table.
preAddColumnHandler(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preAddRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preAddRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preAddRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a new region server group is added
preAddRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preAddRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preAddRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preAppend(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preAppend(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before Append.
preAppend(Append) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preAppend(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preAppend(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preAppendAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preAppendAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before Append but after acquiring rowlock.
preAppendAfterRowLock(Append) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preAppendAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to assigning a specific region.
preAssign(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preBalance(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preBalance(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preBalance(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to requesting rebalancing of the cluster regions, though after the initial checks for regions in transition and the balance switch flag.
preBalance() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preBalance(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preBalance(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a region server group is removed
preBalanceRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to modifying the flag used to enable/disable region balancing.
preBalanceSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
This will be called for every batch mutation operation happening at the server.
preBatchMutate(HRegion, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
 
preBatchMutate(MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preBatchMutate(HRegion, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
The hook to be executed after the process() but before applying the Mutations to region.
preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.tool.WriteSinkCoprocessor
 
preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment>, List<Pair<byte[], String>>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment>, List<Pair<byte[], String>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before bulkLoadHFile.
preBulkLoadHFile(String, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
preBulkLoadHFile(List<Pair<byte[], String>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment>, List<Pair<byte[], String>>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
Verifies user has CREATE privileges on the Column Families involved in the bulkLoadHFile request.
preCheck(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
Check before the delete logic.
preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before checkAndDelete.
preCheckAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before checkAndDelete but after acquiring rowock.
preCheckAndDeleteAfterRowLock(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before checkAndPut.
preCheckAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before checkAndPut but after acquiring rowlock.
preCheckAndPutAfterRowLock(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preCleanupBulkLoad(ObserverContext<RegionCoprocessorEnvironment>, SecureBulkLoadProtos.CleanupBulkLoadRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.BulkLoadObserver
Called as part of SecureBulkLoadEndpoint.cleanupBulkLoad() RPC call.
preCleanupBulkLoad(ObserverContext<RegionCoprocessorEnvironment>, SecureBulkLoadProtos.CleanupBulkLoadRequest) - Method in class org.apache.hadoop.hbase.security.access.AccessController
Authorization security check for SecureBulkLoadProtocol.cleanupBulkLoad()
preClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before clear dead region servers.
preClearDeadServers() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a snapshot is cloned.
preCloneSnapshot(HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preClose(ObserverContext<RegionCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preClose(ObserverContext<RegionCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the region is reported as closed to the master.
preClose(boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked before a region is closed
preClose(ObserverContext<RegionCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preCloseWriter(StoreFile.Writer) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
Subclasses override this method to be called before we close the give writer.
preCloseWriter(StoreFile.Writer) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
preCommitStoreFile(ObserverContext<RegionCoprocessorEnvironment>, byte[], List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preCommitStoreFile(ObserverContext<RegionCoprocessorEnvironment>, byte[], List<Pair<Path, Path>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before moving bulk loaded hfile to region directory.
preCommitStoreFile(byte[], List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preCommitStoreFile(ObserverContext<RegionCoprocessorEnvironment>, byte[], List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationObserver
 
preCommitWriters() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
Subclasses override this method to be called at the end of a successful sequence of append; all appends are processed before this method is called.
preCommitWriters() - Method in class org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
 
preCommitWriters() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
preCommitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
 
preCommitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
preCommitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
 
preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called prior to writing the StoreFiles selected for compaction into a new StoreFile.
preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
preCompact(Store, InternalScanner, ScanType, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Called prior to rewriting the store files selected for compaction
preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends KeyValueScanner>, ScanType, long, InternalScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends KeyValueScanner>, ScanType, long, InternalScanner, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends KeyValueScanner>, ScanType, long, InternalScanner, CompactionRequest, long) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends KeyValueScanner>, ScanType, long, InternalScanner) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
 
preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends KeyValueScanner>, ScanType, long, InternalScanner, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends KeyValueScanner>, ScanType, long, InternalScanner, CompactionRequest, long) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called prior to writing the StoreFiles selected for compaction into a new StoreFile and prior to creating the scanner used to read the input files.
preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends KeyValueScanner>, ScanType, long, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
preCompactScannerOpen(Store, List<StoreFileScanner>, ScanType, long, CompactionRequest, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
preCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, List<StoreFile>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, List<StoreFile>, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, List<StoreFile>, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called prior to selecting the StoreFiles to compact from the list of available candidates.
preCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, List<StoreFile>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
preCompactSelection(Store, List<StoreFile>, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Called prior to selecting the StoreFiles for compaction from the list of currently available candidates.
preCreateCoprocScanner(CompactionRequest, ScanType, long, List<StoreFileScanner>, User, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
Calls coprocessor, if any, to create compaction scanner - before normal scanner creation.
preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a new namespace is created by HMaster.
preCreateNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
 
preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a new table is created by HMaster.
preCreateTable(HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a new table is created by HMaster.
preCreateTableHandler(HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
 
preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the client deletes a value.
preDelete(Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to deleting the entire column family.
preDeleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to deleting the entire column family.
preDeleteColumnHandler(TableName, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before HMaster deletes a namespace It can't bypass the default action, e.g., ctx.bypass() won't have effect.
preDeleteNamespace(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a snapshot is deleted.
preDeleteSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before HMaster deletes a table.
preDeleteTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before HMaster deletes a table.
preDeleteTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preDisable(MasterProcedureEnv, MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
Action before disabling table.
preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
 
preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to disabling a table.
preDisableTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to disabling a table.
preDisableTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preDispatchMerge(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preDispatchMerge(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDispatchMerge(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before dispatching region merge request.
preDispatchMerge(HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDispatchMerge(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preDispatchMerge(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
PreemptiveFastFailException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when the client believes that we are trying to communicate to has been repeatedly unresponsive for a while.
PreemptiveFastFailException(long, long, long, ServerName) - Constructor for exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
PreemptiveFastFailException(long, long, long, ServerName, boolean) - Constructor for exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to enabling a table.
preEnableTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to enabling a table.
preEnableTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment>, Service, String, Message) - Method in interface org.apache.hadoop.hbase.coprocessor.EndpointObserver
Called before an Endpoint service method is invoked.
preEndpointInvocation(Service, String, Message) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment>, Service, String, Message) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preExists(ObserverContext<RegionCoprocessorEnvironment>, Get, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preExists(ObserverContext<RegionCoprocessorEnvironment>, Get, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the client tests for existence using a Get.
preExists(Get) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preExists(ObserverContext<RegionCoprocessorEnvironment>, Get, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Key for the PREFETCH_BLOCKS_ON_OPEN attribute.
PREFETCH_BLOCKS_ON_OPEN_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to prefetch all blocks of a given file into the block cache when the file is opened.
PrefetchExecutor - Class in org.apache.hadoop.hbase.io.hfile
 
PrefetchExecutor() - Constructor for class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
 
prefix - Variable in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
prefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
 
prefix(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Adds this instance's identifier as a prefix to the passed str
PREFIX_LENGTH_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
 
PREFIX_LENGTH_KEY_DEPRECATED - Static variable in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
Deprecated.
PrefixFilter - Class in org.apache.hadoop.hbase.filter
Pass results that have same row prefix.
PrefixFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.PrefixFilter
 
PrefixKeyDeltaEncoder - Class in org.apache.hadoop.hbase.io.encoding
Compress key by storing size of common prefix with previous KeyValue and storing raw size of rest.
PrefixKeyDeltaEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
 
PrefixTreeArrayReversibleScanner - Class in org.apache.hadoop.hbase.codec.prefixtree.decode
Methods for going backwards through a PrefixTree block.
PrefixTreeArrayReversibleScanner(PrefixTreeBlockMeta, int, int, int, int) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayReversibleScanner
construct
PrefixTreeArrayScanner - Class in org.apache.hadoop.hbase.codec.prefixtree.decode
Extends PtCell and manipulates its protected fields.
PrefixTreeArrayScanner(PrefixTreeBlockMeta, int, int, int, int) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
construct
PrefixTreeArraySearcher - Class in org.apache.hadoop.hbase.codec.prefixtree.decode
Searcher extends the capabilities of the Scanner + ReversibleScanner to add the ability to position itself on a requested Cell without scanning through cells before it.
PrefixTreeArraySearcher(PrefixTreeBlockMeta, int, int, int, int) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
construct
PrefixTreeBlockMeta - Class in org.apache.hadoop.hbase.codec.prefixtree
Information about the block.
PrefixTreeBlockMeta() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
constructors
PrefixTreeBlockMeta(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
PrefixTreeBlockMeta(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
PrefixTreeCell - Class in org.apache.hadoop.hbase.codec.prefixtree.decode
As the PrefixTreeArrayScanner moves through the tree bytes, it changes the values in the fields of this class so that Cell logic can be applied, but without allocating new memory for every Cell iterated through.
PrefixTreeCell() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
PrefixTreeCodec - Class in org.apache.hadoop.hbase.codec.prefixtree
Deprecated.
Since 1.2.7. Will be removed in 2.0.0. Write the dev list if you would like to take on the maintainence of this facility.
PrefixTreeCodec() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
Deprecated.
no-arg constructor for reflection
PrefixTreeEncoder - Class in org.apache.hadoop.hbase.codec.prefixtree.encode
This is the primary class for converting a CellOutputStream into an encoded byte[].
PrefixTreeEncoder(OutputStream, boolean) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
construct
prefixTreeEncoder - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
fields
prefixTreeEncoder - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
fields
PrefixTreeSeeker - Class in org.apache.hadoop.hbase.codec.prefixtree
These methods have the same definition as any implementation of the EncodedSeeker.
PrefixTreeSeeker(boolean) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
preFlush(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preFlush(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preFlush(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
preFlush(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before a Store's memstore is flushed to disk.
preFlush(Store, InternalScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked before a memstore flush
preFlush() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked before a memstore flush
preFlush(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, KeyValueScanner, InternalScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, KeyValueScanner, InternalScanner, long) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, KeyValueScanner, InternalScanner) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
 
preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, KeyValueScanner, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, KeyValueScanner, InternalScanner, long) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before a memstore is flushed to disk and prior to creating the scanner to read from the memstore.
preFlushScannerOpen(Store, KeyValueScanner, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
preGet(Get, List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], Result) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], Result) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before a client makes a GetClosestRowBefore request.
preGetClosestRowBefore(byte[], byte[], Result) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], Result) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preGetClusterStatus(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preGetClusterStatus(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preGetClusterStatus(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before get cluster status.
preGetClusterStatus() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preGetClusterStatus(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a getNamespaceDescriptor request has been processed.
preGetNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics
 
preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
 
preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the client performs a Get
preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Deprecated.
Use preGetTableDescriptors with regex instead.
preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a getTableDescriptors request has been processed.
preGetTableDescriptors(List<TableName>, List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
Deprecated.
preGetTableDescriptors(List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a getTableNames request has been processed.
preGetTableNames(List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before Increment.
preIncrement(Increment) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preIncrementAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preIncrementAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before Increment but after acquiring rowlock.
preIncrementAfterRowLock(Increment) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preIncrementAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preIncrementColumnValue(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preIncrementColumnValue(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], long, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Deprecated.
This hook is no longer called by the RegionServer
preIncrementColumnValue(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a listNamespaceDescriptors request has been processed.
preListNamespaceDescriptors(List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preListProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preListProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preListProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a listProcedures request has been processed.
preListProcedures() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preListProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preListProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before listSnapshots request has been processed.
preListSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preLogArchive(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
 
preLogArchive(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
The WAL is going to be archived.
preLogRoll(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
 
preLogRoll(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
The WAL is going to be rolled.
preLogRoll(Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Call before the master initialization is set to true.
preMasterInitialization() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
preMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
Called before the regions merge.
preMerge(HRegion, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
preMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, List<Mutation>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, List<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
This will be called before PONR step as part of regions merge transaction.
preMergeCommit(HRegion, HRegion, List<Mutation>) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, List<Mutation>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to modifying a column family's attributes.
preModifyColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to modifying a column family's attributes.
preModifyColumnHandler(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to modifying a namespace's properties.
preModifyNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to modifying a table's properties.
preModifyTable(TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to modifying a table's properties.
preModifyTableHandler(TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to moving a given region from one region server to another.
preMove(HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preMoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preMoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preMoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before servers are moved to target region server group
preMoveServers(Set<Address>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preMoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preMoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before servers are moved to target region server group
preMoveServersAndTables(Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preMoveTables(ObserverContext<MasterCoprocessorEnvironment>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preMoveTables(ObserverContext<MasterCoprocessorEnvironment>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preMoveTables(ObserverContext<MasterCoprocessorEnvironment>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before tables are moved to target region server group
preMoveTables(Set<TableName>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preMoveTables(ObserverContext<MasterCoprocessorEnvironment>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preMoveTables(ObserverContext<MasterCoprocessorEnvironment>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the region is reported as open to the master.
preOpen() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked before a region open.
preOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.tool.WriteSinkCoprocessor
 
prepare(boolean) - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
prepare(boolean) - Method in class org.apache.hadoop.hbase.client.FlushRegionCallable
 
prepare(boolean) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
prepare(boolean) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
Prepare for connection to the server hosting region with row from tablename.
prepare(boolean) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
Prepare by setting up any connections to servers, etc., ahead of RetryingCallable.call(int) invocation.
prepare(boolean) - Method in class org.apache.hadoop.hbase.client.ReversedScannerCallable
 
prepare(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
prepare(E) - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
 
prepare() - Method in class org.apache.hadoop.hbase.executor.EventHandler
Event handlers should do all the necessary checks in this method (rather than in the constructor, or in process()) so that the caller, which is mostly executed in the ipc context can fail fast.
prepare() - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
 
prepare() - Method in class org.apache.hadoop.hbase.master.handler.DisableTableHandler
 
prepare() - Method in class org.apache.hadoop.hbase.master.handler.EnableTableHandler
 
prepare() - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
prepare() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
 
prepare() - Method in class org.apache.hadoop.hbase.master.snapshot.DisabledTableSnapshotHandler
 
prepare() - Method in class org.apache.hadoop.hbase.master.snapshot.EnabledTableSnapshotHandler
 
prepare() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
 
prepare() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
prepare(RegionServerServices) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
Check merge inputs and prepare the transaction.
prepare(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
Does checks on merge inputs.
prepare() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
Check split inputs and prepare the transaction.
prepare() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
Does checks on split inputs.
prepareBulkLoad(TableName) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
prepareBulkLoad(byte[], String) - Method in interface org.apache.hadoop.hbase.regionserver.Region.BulkLoadListener
Called before an HFile is actually loaded
prepareBulkLoad(RpcController, SecureBulkLoadProtos.PrepareBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.PrepareBulkLoadResponse>) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
 
prepareDecoding(int, int, ByteBuffer, ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockDecodingContext
Perform all actions that need to be done before the encoder's real decoding process.
prepareDecoding(int, int, ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
 
prepareDelete(Delete) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
prepareDelete(Delete) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Prepare a delete for a row mutation processor
prepareDeleteTimestamps(Mutation, Map<byte[], List<Cell>>, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
prepareDeleteTimestamps(Mutation, Map<byte[], List<Cell>>, byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Set up correct timestamps in the KVs in Delete object.
prepareEncoder(PrefixTreeEncoder, OutputStream, boolean) - Static method in class org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderFactory
helper
prepareEncoding(DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
prepare to start a new encoding.
prepareForBlockReader(boolean) - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
Prepares the streams for block reader.
prepareHFileQueue(Path, Table, Deque<LoadIncrementalHFiles.LoadQueueItem>, boolean) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
Prepare a collection of LoadIncrementalHFiles.LoadQueueItem from list of source hfiles contained in the passed directory and validates whether the prepared queue has all the valid table column families in it.
prepareLogReplay(ServerName, Set<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
Mark regions in recovering state when distributedLogReplay are set true
prepareMutationsForMerge(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, List<Mutation>, int) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
 
prepareRSGroupForTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
prepareTask(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Prepare the new task
prepareTask(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
prepareToSplit() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Give the region a chance to prepare before it is split.
prepareWithTableLock() - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
Called from prepare() while holding the table lock.
prependPBMagic(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Prepend the passed bytes with four bytes of magic, ProtobufUtil.PB_MAGIC, to flag what follows as a protobuf in hbase.
prependTokenToBuffer(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
prePrepareBulkLoad(ObserverContext<RegionCoprocessorEnvironment>, SecureBulkLoadProtos.PrepareBulkLoadRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.BulkLoadObserver
Called as part of SecureBulkLoadEndpoint.prepareBulkLoad() RPC call.
prePrepareBulkLoad(ObserverContext<RegionCoprocessorEnvironment>, SecureBulkLoadProtos.PrepareBulkLoadRequest) - Method in class org.apache.hadoop.hbase.security.access.AccessController
Authorization check for SecureBulkLoadProtocol.prepareBulkLoad()
prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment>, Mutation, Cell, byte[], Get) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment>, Mutation, Cell, byte[], Get) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the server updates the timestamp for version delete with latest timestamp.
prePrepareTimeStampForDeleteVersion(Mutation, Cell, byte[], Get) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment>, Mutation, Cell, byte[], Get) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preProcess(HRegion, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
 
preProcess(HRegion, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
The hook to be executed before process().
prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.constraint.ConstraintProcessor
 
prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
 
prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the client stores a value.
prePut(Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to marking a given region as offline.
preRegionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a region server group is removed
preRemoveRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preRemoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preRemoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preRemoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before servers are removed from rsgroup
preRemoveServers(Set<Address>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preRemoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preRemoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>, List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>, List<AdminProtos.WALEntry>, CellScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
This will be called before executing replication request to shipping log entries.
preReplicateLogEntries(List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>, List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a snapshot is restored.
preRestoreSnapshot(HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
This will be called before the roll back of the regions merge.
preRollBackMerge(HRegion, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preRollBackSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preRollBackSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
This will be called before the roll back of the split region is completed
preRollBackSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked just before the rollback of a failed split is started
preRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
preRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
This will be called before executing user request to roll a region server WAL.
preRollWALWriterRequest() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
preRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the client closes a scanner.
preScannerClose(InternalScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preScannerNext(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preScannerNext(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the client asks for the next row on a scanner.
preScannerNext(InternalScanner, List<Result>, int) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preScannerNext(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preScannerNext(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the client opens a new scanner.
preScannerOpen(Scan) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preSelect(List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
Called before coprocessor preCompactSelection and should filter the candidates for coprocessor; i.e.
preSelectCompactionForCoprocessor(Collection<StoreFile>, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
 
preSelectFilesForCoprocessor(StripeCompactionPolicy.StripeInformationProvider, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
 
preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before the quota for the namespace is stored.
preSetNamespaceQuota(String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, Admin.MasterSwitchType) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to setting split / merge switch
preSetSplitOrMergeEnabled(boolean, Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before the quota for the table is stored.
preSetTableQuota(TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before the quota for the user is stored.
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before the quota for the user on the specified table is stored.
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before the quota for the user on the specified namespace is stored.
preSetUserQuota(String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preSetUserQuota(String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preSetUserQuota(String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preShutdown(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preShutdown(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preShutdown(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to shutting down the full HBase cluster, including this HMaster process.
preShutdown() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preShutdown(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preShutdown(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before a new snapshot is taken.
preSnapshot(HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preSnapshotOperation() - Method in class org.apache.hadoop.hbase.regionserver.HStore
Sets the store up for a region level snapshot operation.
preSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preSplit(ObserverContext<RegionCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Deprecated.
Use preSplit( final ObserverContext<RegionCoprocessorEnvironment> c, byte[] splitRow)
preSplit(ObserverContext<RegionCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the region is split.
preSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked just before a split
preSplit(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Invoked just before a split
preSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preSplit(ObserverContext<RegionCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preSplitAfterPONR(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preSplitAfterPONR(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
This will be called after PONR step as part of split transaction Calling ObserverContext.bypass() has no effect in this hook.
preSplitAfterPONR() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preSplitBeforePONR(ObserverContext<RegionCoprocessorEnvironment>, byte[], List<Mutation>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preSplitBeforePONR(ObserverContext<RegionCoprocessorEnvironment>, byte[], List<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
This will be called before PONR step as part of split transaction.
preSplitBeforePONR(byte[], List<Mutation>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
PressureAwareCompactionThroughputController - Class in org.apache.hadoop.hbase.regionserver.throttle
A throughput controller which uses the follow schema to limit throughput If compaction pressure is greater than 1.0, no limitation. In off peak hours, use a fixed throughput limitation "hbase.hstore.compaction.throughput.offpeak" In normal hours, the max throughput is tuned between "hbase.hstore.compaction.throughput.lower.bound" and "hbase.hstore.compaction.throughput.higher.bound", using the formula "lower + (higer - lower) * compactionPressure", where compactionPressure is in range [0.0, 1.0]
PressureAwareCompactionThroughputController() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
 
PressureAwareFlushThroughputController - Class in org.apache.hadoop.hbase.regionserver.throttle
A throughput controller which uses the follow schema to limit throughput If flush pressure is greater than or equal to 1.0, no limitation. In normal case, the max throughput is tuned between "hbase.hstore.flush.throughput.lower.bound" and "hbase.hstore.flush.throughput.upper.bound", using the formula "lower + (upper - lower) * flushPressure", where flushPressure is in range [0.0, 1.0)
PressureAwareFlushThroughputController() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
 
PressureAwareThroughputController - Class in org.apache.hadoop.hbase.regionserver.throttle
 
PressureAwareThroughputController() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
preStop(String) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
preStopMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preStopMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preStopMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called immediately prior to stopping this HMaster process.
preStopMaster() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preStopMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preStopMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
Called before stopping region server.
preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFile.Reader) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFile.Reader) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before creation of Reader for a store file.
preStoreFileReaderOpen(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, Scan, NavigableSet<byte[]>, KeyValueScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, Scan, NavigableSet<byte[]>, KeyValueScanner) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
 
preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, Scan, NavigableSet<byte[]>, KeyValueScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before a store opens a new scanner.
preStoreScannerOpen(Store, Scan, NavigableSet<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
preTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before the table memstore is flushed to disk.
preTableFlush(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before HMaster truncates a table.
preTruncateTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before HMaster truncates a table.
preTruncateTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
prettyPrint(String) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Use logging.
PrettyPrinter - Class in org.apache.hadoop.hbase.util
 
PrettyPrinter() - Constructor for class org.apache.hadoop.hbase.util.PrettyPrinter
 
PrettyPrinter.Unit - Enum in org.apache.hadoop.hbase.util
 
prettyPrintJournal() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
preUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
preUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to unassigning a given region.
preUnassign(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
preUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
prevCell - Variable in class org.apache.hadoop.hbase.io.encoding.EncodingState
The previous Cell the encoder encoded.
previous() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayReversibleScanner
methods
previous() - Method in interface org.apache.hadoop.hbase.codec.prefixtree.scanner.ReversibleCellScanner
Try to position the scanner one Cell before the current position.
previousKey(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Decrement the timestamp.
previousRow(boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayReversibleScanner
 
previousRow(boolean) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.scanner.ReversibleCellScanner
Try to position the scanner in the row before the current row.
prevPtr - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The previous entry in the LRU list (towards LRU)
preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
Implementers should override this version of the method and leave the deprecated one as-is.
preWALRestore(ObserverContext<RegionCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before a WALEdit replayed for this region.
preWALRestore(ObserverContext<RegionCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
preWALRestore(HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preWALRestore(HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
preWALRoll(ObserverContext<? extends WALCoprocessorEnvironment>, Path, Path) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
 
preWALRoll(ObserverContext<? extends WALCoprocessorEnvironment>, Path, Path) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
Called before rolling the current WAL
preWALRoll(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
Called before rolling the current WAL
preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
Implementers should override this method and leave the deprecated version as-is.
preWALWrite(ObserverContext<WALCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
 
preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
Called before a WALEdit is writen to WAL.
preWALWrite(ObserverContext<WALCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
preWALWrite(HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
 
primaryOperationTimeout - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
principal - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
 
print(Object) - Method in class org.apache.hadoop.hbase.hbtop.terminal.AbstractTerminalPrinter
 
print(char) - Method in class org.apache.hadoop.hbase.hbtop.terminal.AbstractTerminalPrinter
 
print(short) - Method in class org.apache.hadoop.hbase.hbtop.terminal.AbstractTerminalPrinter
 
print(int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.AbstractTerminalPrinter
 
print(long) - Method in class org.apache.hadoop.hbase.hbtop.terminal.AbstractTerminalPrinter
 
print(float) - Method in class org.apache.hadoop.hbase.hbtop.terminal.AbstractTerminalPrinter
 
print(double) - Method in class org.apache.hadoop.hbase.hbtop.terminal.AbstractTerminalPrinter
 
print(String) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
 
print(String) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
print(Object) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
print(char) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
print(short) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
print(int) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
print(long) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
print(float) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
print(double) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
print(boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
 
print(String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
printAssignmentPlan(FavoredNodesPlan) - Static method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
Print the assignment plan to the system output stream
printDispersionScores(TableName, SnapshotOfRegionAssignmentFromMeta, int, FavoredNodesPlan, boolean) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
 
printFormat(String, Object...) - Method in class org.apache.hadoop.hbase.hbtop.terminal.AbstractTerminalPrinter
 
printFormat(String, Object...) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
printLocalityAndDispersionForCurrentPlan(Map<String, Map<String, Float>>) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
 
printThreadInfo(PrintStream, String) - Static method in class org.apache.hadoop.hbase.util.Threads
Print all of the thread's information and stack traces.
printUsage() - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
 
printUsage(String) - Static method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
 
printUsage(String, String) - Static method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
 
printUsage() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
printUsage(String, String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
printUsageAndExit(String, int) - Static method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
 
printUsageAndExit() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
printUsageAndExit() - Static method in class org.apache.hadoop.hbase.util.hbck.OfflineMetaRepair
 
priority - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
 
priority - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
Chaining priority
PRIORITY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
PRIORITY_HIGHEST - Static variable in interface org.apache.hadoop.hbase.Coprocessor
Highest installation priority
PRIORITY_LOWEST - Static variable in interface org.apache.hadoop.hbase.Coprocessor
Lowest installation priority
PRIORITY_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
PRIORITY_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
PRIORITY_SYSTEM - Static variable in interface org.apache.hadoop.hbase.Coprocessor
High (system) installation priority
PRIORITY_UNSET - Static variable in class org.apache.hadoop.hbase.HConstants
QOS attributes: these attributes are used to demarcate RPC call processing by different set of handlers.
PRIORITY_USER - Static variable in interface org.apache.hadoop.hbase.Coprocessor
Default installation priority for user coprocessors
PRIORITY_USER - Static variable in interface org.apache.hadoop.hbase.regionserver.Store
 
PriorityFunction - Interface in org.apache.hadoop.hbase.ipc
Function to figure priority of incoming request.
Procedure - Class in org.apache.hadoop.hbase.procedure
A globally-barriered distributed procedure.
Procedure(ProcedureCoordinator, ForeignExceptionDispatcher, long, long, String, byte[], List<String>) - Constructor for class org.apache.hadoop.hbase.procedure.Procedure
Creates a procedure.
Procedure(ProcedureCoordinator, long, long, String, byte[], List<String>) - Constructor for class org.apache.hadoop.hbase.procedure.Procedure
Create a procedure.
Procedure<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
Base Procedure class responsible to handle the Procedure Metadata e.g.
Procedure() - Constructor for class org.apache.hadoop.hbase.procedure2.Procedure
 
ProcedureAbortedException - Exception in org.apache.hadoop.hbase.procedure2
Thrown when a procedure is aborted
ProcedureAbortedException() - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureAbortedException
default constructor
ProcedureAbortedException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureAbortedException
Constructor
procedureAdded(long) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureExecutor.ProcedureExecutorListener
 
ProcedureCoordinator - Class in org.apache.hadoop.hbase.procedure
This is the master side of a distributed complex procedure execution.
ProcedureCoordinator(ProcedureCoordinatorRpcs, ThreadPoolExecutor) - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
Create and start a ProcedureCoordinator.
ProcedureCoordinator(ProcedureCoordinatorRpcs, ThreadPoolExecutor, long, long) - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
Create and start a ProcedureCoordinator.
ProcedureCoordinatorRpcs - Interface in org.apache.hadoop.hbase.procedure
RPCs for the coordinator to run a barriered procedure with subprocedures executed at distributed members.
ProcedureException - Exception in org.apache.hadoop.hbase.procedure2
 
ProcedureException() - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureException
default constructor
ProcedureException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureException
Constructor
ProcedureException(Throwable) - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureException
 
ProcedureExecutor<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
Thread Pool that executes the submitted procedures.
ProcedureExecutor(Configuration, TEnvironment, ProcedureStore) - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
ProcedureExecutor(Configuration, TEnvironment, ProcedureStore, ProcedureRunnableSet) - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
ProcedureExecutor.FailedProcedureInfo - Class in org.apache.hadoop.hbase.procedure2
 
ProcedureExecutor.FailedProcedureInfo(long, String, String, ProcedureProtos.ProcedureState, long, NonceKey, ErrorHandlingProtos.ForeignExceptionMessage, long, long, byte[]) - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.FailedProcedureInfo
 
ProcedureExecutor.ProcedureExecutorListener - Interface in org.apache.hadoop.hbase.procedure2
 
ProcedureExecutor.Testing - Class in org.apache.hadoop.hbase.procedure2
 
ProcedureExecutor.Testing() - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.Testing
 
procedureFinished(long) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureExecutor.ProcedureExecutorListener
 
ProcedureInfo - Class in org.apache.hadoop.hbase
Procedure information
ProcedureInfo(long, String, String, ProcedureProtos.ProcedureState, long, NonceKey, ErrorHandlingProtos.ForeignExceptionMessage, long, long, byte[]) - Constructor for class org.apache.hadoop.hbase.ProcedureInfo
 
ProcedureInMemoryChore<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
Special procedure used as a chore.
ProcedureInMemoryChore(int) - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureInMemoryChore
 
procedureLoaded(long) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureExecutor.ProcedureExecutorListener
 
ProcedureManager - Class in org.apache.hadoop.hbase.procedure
 
ProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureManager
 
ProcedureManagerHost<E extends ProcedureManager> - Class in org.apache.hadoop.hbase.procedure
Provides the common setup framework and runtime services for globally barriered procedure invocation from HBase services.
ProcedureManagerHost() - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
 
ProcedureMember - Class in org.apache.hadoop.hbase.procedure
Process to kick off and manage a running Subprocedure on a member.
ProcedureMember(ProcedureMemberRpcs, ThreadPoolExecutor, SubprocedureFactory) - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureMember
Instantiate a new ProcedureMember.
ProcedureMemberRpcs - Interface in org.apache.hadoop.hbase.procedure
This is the notification interface for Procedures that encapsulates message passing from members to a coordinator.
ProcedurePrepareLatch - Class in org.apache.hadoop.hbase.master.procedure
Latch used by the Master to have the prepare() sync behaviour for old clients, that can only get exceptions in a synchronous way.
ProcedurePrepareLatch() - Constructor for class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
 
ProcedurePrepareLatch.CompatibilityLatch - Class in org.apache.hadoop.hbase.master.procedure
 
ProcedurePrepareLatch.CompatibilityLatch() - Constructor for class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.CompatibilityLatch
 
ProcedureRunnableSet - Interface in org.apache.hadoop.hbase.procedure2
Keep track of the runnable procedures
procedures - Variable in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
 
ProcedureSimpleRunQueue - Class in org.apache.hadoop.hbase.procedure2
Simple runqueue for the procedures
ProcedureSimpleRunQueue() - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
 
ProcedureStore - Interface in org.apache.hadoop.hbase.procedure2.store
The ProcedureStore is used by the executor to persist the state of each procedure execution.
ProcedureStore.ProcedureIterator - Interface in org.apache.hadoop.hbase.procedure2.store
An Iterator over a collection of Procedure
ProcedureStore.ProcedureLoader - Interface in org.apache.hadoop.hbase.procedure2.store
Interface passed to the ProcedureStore.load() method to handle the store-load events.
ProcedureStore.ProcedureStoreListener - Interface in org.apache.hadoop.hbase.procedure2.store
Store listener interface.
ProcedureStoreBase - Class in org.apache.hadoop.hbase.procedure2.store
Base class for ProcedureStores.
ProcedureStoreBase() - Constructor for class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
 
ProcedureStoreTracker - Class in org.apache.hadoop.hbase.procedure2.store
Keeps track of live procedures.
ProcedureStoreTracker() - Constructor for class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
ProcedureStoreTracker.BitSetNode - Class in org.apache.hadoop.hbase.procedure2.store
 
ProcedureStoreTracker.BitSetNode(long, boolean) - Constructor for class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
ProcedureStoreTracker.BitSetNode(long, long[], long[]) - Constructor for class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
ProcedureStoreTracker.DeleteState - Enum in org.apache.hadoop.hbase.procedure2.store
 
ProcedureSyncWait - Class in org.apache.hadoop.hbase.master.procedure
Helper to synchronously wait on conditions.
ProcedureSyncWait.Predicate<T> - Interface in org.apache.hadoop.hbase.master.procedure
 
ProcedureWALFile - Class in org.apache.hadoop.hbase.procedure2.store.wal
Describes a WAL File
ProcedureWALFile(FileSystem, FileStatus) - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
ProcedureWALFile(FileSystem, Path, ProcedureProtos.ProcedureWALHeader, long, long) - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
ProcedureWALFormat - Class in org.apache.hadoop.hbase.procedure2.store.wal
Helper class that contains the WAL serialization utils.
ProcedureWALFormat.InvalidWALDataException - Exception in org.apache.hadoop.hbase.procedure2.store.wal
 
ProcedureWALFormat.InvalidWALDataException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat.InvalidWALDataException
 
ProcedureWALFormat.InvalidWALDataException(Throwable) - Constructor for exception org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat.InvalidWALDataException
 
ProcedureWALFormatReader - Class in org.apache.hadoop.hbase.procedure2.store.wal
Helper class that loads the procedures stored in a WAL
ProcedureWALFormatReader(ProcedureStoreTracker) - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
 
ProcedureWALPrettyPrinter - Class in org.apache.hadoop.hbase.procedure2.store.wal
ProcedureWALPrettyPrinter prints the contents of a given ProcedureWAL file
ProcedureWALPrettyPrinter() - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
 
ProcedureYieldException - Exception in org.apache.hadoop.hbase.procedure2
 
ProcedureYieldException() - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureYieldException
default constructor
ProcedureYieldException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureYieldException
Constructor
proceed() - Method in interface org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.HttpInteraction
Called by the filter after it decides that the request may proceed.
process(RpcController, RowProcessorProtos.ProcessRequest, RpcCallback<RowProcessorProtos.ProcessResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
Pass a processor to region to process multiple rows atomically.
process() - Method in class org.apache.hadoop.hbase.executor.EventHandler
This method is the main processing loop to be implemented by the various subclasses.
process() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
 
process() - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
 
process() - Method in class org.apache.hadoop.hbase.master.handler.DisableTableHandler
 
process() - Method in class org.apache.hadoop.hbase.master.handler.DispatchMergingRegionHandler
 
process() - Method in class org.apache.hadoop.hbase.master.handler.EnableTableHandler
 
process() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
 
process() - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
process() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
Execute the core common portions of taking a snapshot.
process() - Method in class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischargeHandler
 
process() - Method in class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
 
process() - Method in class org.apache.hadoop.hbase.regionserver.handler.FinishRegionRecoveringHandler
 
process() - Method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
 
process() - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
 
process() - Method in class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
 
process() - Method in class org.apache.hadoop.hbase.regionserver.handler.WALSplitterHandler
 
process(long, HRegion, List<Mutation>, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
HRegion handles the locks and MVCC and invokes this method properly.
process(WatchedEvent) - Method in class org.apache.hadoop.hbase.zookeeper.EmptyWatcher
 
process(WatchedEvent) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Method called from ZooKeeper for events and connection status.
PROCESS_CALL_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
PROCESS_CALL_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
processBatch(List<? extends Row>, TableName, ExecutorService, Object[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
processBatch(List<? extends Row>, byte[], ExecutorService, Object[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
processBatchCallback(List<? extends Row>, TableName, ExecutorService, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.HConnection
processBatchCallback(List<? extends Row>, byte[], ExecutorService, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
processBatchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
Process a mixed batch of Get, Put and Delete actions.
processBatchCallback(List<? extends Row>, TableName, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.util.MultiHConnection
Randomly pick a connection and process the batch of actions for a given table
processDeadServer(ServerName, boolean) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
processedCall(int) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
processedCall(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
processException(Throwable) - Method in class org.apache.hadoop.hbase.rest.ResourceBase
 
processFile(Path) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
 
processFile(Configuration, Path) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
Reads a log file and outputs its contents.
processFile(Configuration, Path) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
reads a log file and outputs its contents, one transaction at a time, as specified by the currently configured options
processKV(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context, Put, Delete) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
 
processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
 
processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
This method is called to process the options after they have been parsed.
processParameter(String, String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
processParameters(URI) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
processProcedureWALFile(ProcedureWALFile) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
 
processRegionMergeRequest(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, RegionMergeCoordination.RegionMergeDetails) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
 
processRegionMergeRequest(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, RegionMergeCoordination.RegionMergeDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
 
processRequest(ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
processResult(int, String, Object, String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateAsyncCallback
 
processResult(int, String, Object, String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateRescanAsyncCallback
 
processResult(int, String, Object) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.DeleteAsyncCallback
 
processResult(int, String, Object, byte[], Stat) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.GetDataAsyncCallback
 
processResult(int, String, Object, String) - Method in class org.apache.hadoop.hbase.master.OfflineCallback
 
processRow(Result) - Method in class org.apache.hadoop.hbase.client.MetaScanner.DefaultMetaScannerVisitor
 
processRow(Result) - Method in interface org.apache.hadoop.hbase.client.MetaScanner.MetaScannerVisitor
Visitor method that accepts a RowResult and the meta region location.
processRow(Result) - Method in class org.apache.hadoop.hbase.client.MetaScanner.TableMetaScannerVisitor
 
processRowInternal(Result) - Method in class org.apache.hadoop.hbase.client.MetaScanner.DefaultMetaScannerVisitor
 
processRowsWithLocks(RowProcessor<?, ?>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
processRowsWithLocks(RowProcessor<?, ?>, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
processRowsWithLocks(RowProcessor<?, ?>, long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
processRowsWithLocks(RowProcessor<?, ?>) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Performs atomic multiple reads and writes on a given row.
processRowsWithLocks(RowProcessor<?, ?>, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Performs atomic multiple reads and writes on a given row.
processRowsWithLocks(RowProcessor<?, ?>, long, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Performs atomic multiple reads and writes on a given row.
processTransition(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, SplitTransactionCoordination.SplitTransactionDetails) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
Required by AssignmentManager
processTransition(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, SplitTransactionCoordination.SplitTransactionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
 
ProcessUtils - Class in org.apache.hadoop.hbase.util
Process related utilities.
ProfileOutputServlet - Class in org.apache.hadoop.hbase.http
Servlet to serve files generated by ProfileServlet
ProfileOutputServlet() - Constructor for class org.apache.hadoop.hbase.http.ProfileOutputServlet
 
ProfileServlet - Class in org.apache.hadoop.hbase.http
Servlet that runs async-profiler as web-endpoint.
ProfileServlet() - Constructor for class org.apache.hadoop.hbase.http.ProfileServlet
 
ProfileServlet.DisabledServlet - Class in org.apache.hadoop.hbase.http
 
ProfileServlet.DisabledServlet() - Constructor for class org.apache.hadoop.hbase.http.ProfileServlet.DisabledServlet
 
progress - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
progress() - Method in interface org.apache.hadoop.hbase.util.CancelableProgressable
Report progress.
progress() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
PropagatingConfigurationObserver - Interface in org.apache.hadoop.hbase.conf
This extension to ConfigurationObserver allows the configuration to propagate to the children of the current ConfigurationObserver.
PROPS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
ProtobufLogReader - Class in org.apache.hadoop.hbase.regionserver.wal
A Protobuf based WAL has the following structure:
ProtobufLogReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
ProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
Writer for protobuf-based WAL.
ProtobufLogWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
ProtobufMessageBodyConsumer - Class in org.apache.hadoop.hbase.rest.provider.consumer
Adapter for hooking up Jersey content processing dispatch to ProtobufMessageHandler interface capable handlers for decoding protobuf input.
ProtobufMessageBodyConsumer() - Constructor for class org.apache.hadoop.hbase.rest.provider.consumer.ProtobufMessageBodyConsumer
 
ProtobufMessageBodyProducer - Class in org.apache.hadoop.hbase.rest.provider.producer
An adapter between Jersey and ProtobufMessageHandler implementors.
ProtobufMessageBodyProducer() - Constructor for class org.apache.hadoop.hbase.rest.provider.producer.ProtobufMessageBodyProducer
 
ProtobufMessageHandler - Interface in org.apache.hadoop.hbase.rest
Common interface for models capable of supporting protobuf marshalling and unmarshalling.
ProtobufStreamingUtil - Class in org.apache.hadoop.hbase.rest
 
ProtobufStreamingUtil(ResultScanner, String, int, int) - Constructor for class org.apache.hadoop.hbase.rest.ProtobufStreamingUtil
 
ProtobufUtil - Class in org.apache.hadoop.hbase.protobuf
Protobufs utility.
PROTOCOL_HTTP - Static variable in class org.apache.hadoop.hbase.http.log.LogLevel
 
PROTOCOL_HTTPS - Static variable in class org.apache.hadoop.hbase.http.log.LogLevel
 
ProtoUtil - Class in org.apache.hadoop.hbase.util
 
ProtoUtil() - Constructor for class org.apache.hadoop.hbase.util.ProtoUtil
 
ptSearcher - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
publish(ClusterStatus) - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
 
publish(ClusterStatus) - Method in interface org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
 
publishReadFailure(String, String) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerStdOutSink
 
publishReadFailure(ServerName, HRegionInfo, Exception) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
 
publishReadFailure(ServerName, HRegionInfo, HColumnDescriptor, Exception) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
 
publishReadFailure(String, String) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.ZookeeperStdOutSink
 
publishReadTiming(String, String, long) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerStdOutSink
 
publishReadTiming(ServerName, HRegionInfo, HColumnDescriptor, long) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
 
publishReadTiming(String, String, long) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.ZookeeperStdOutSink
 
publishWriteFailure(ServerName, HRegionInfo, Exception) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
 
publishWriteFailure(ServerName, HRegionInfo, HColumnDescriptor, Exception) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
 
publishWriteTiming(ServerName, HRegionInfo, HColumnDescriptor, long) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
 
purge() - Method in class org.apache.hadoop.hbase.util.WeakObjectPool
Removes stale references of shared objects from the pool.
purgeTimeout - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
put(Put) - Method in class org.apache.hadoop.hbase.client.HTable
Puts some data in the table.
put(List<Put>) - Method in class org.apache.hadoop.hbase.client.HTable
Puts some data in the table, in batch.
put(TableName, Put) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
The put request will be buffered by its corresponding buffer queue.
put(TableName, List<Put>) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
The puts request will be buffered by their corresponding buffer queue.
put(byte[], List<Put>) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
Deprecated.
put(TableName, Put, int) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
The put request will be buffered by its corresponding buffer queue.
put(byte[], Put, int) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
Deprecated.
put(byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
Deprecated.
put(Put) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
put(List<Put>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
Put - Class in org.apache.hadoop.hbase.client
Used to perform Put operations for a single row.
Put(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Put
Create a Put operation for the specified row.
Put(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.Put
Create a Put operation for the specified row, using a given timestamp.
Put(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Put
We make a copy of the passed in row key to keep local.
Put(ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.client.Put
 
Put(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.client.Put
 
Put(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.client.Put
We make a copy of the passed in row key to keep local.
Put(Put) - Constructor for class org.apache.hadoop.hbase.client.Put
Copy constructor.
put(Put) - Method in interface org.apache.hadoop.hbase.client.Table
Puts some data in the table.
put(List<Put>) - Method in interface org.apache.hadoop.hbase.client.Table
Puts some data in the table, in batch.
put(Field, Object) - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
 
put(Field, FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
 
put(Record.Entry) - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
 
put(Field, FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.Record
 
put(byte[], int) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
Put the magic record out to the specified byte array position.
put(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
put(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
put(Put) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
put(K, V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Insert a key-value mapping into the map.
put(Put) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Puts some data in the table.
put(String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a PUT request
put(String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a PUT request
put(Cluster, String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a PUT request
put(Cluster, String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a PUT request
put(String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a PUT request
put(Cluster, String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a PUT request
put(Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
put(List<Put>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
put(NamespacesInstanceModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
Build a response for PUT alter namespace with properties specified.
put(CellSetModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
 
put(ScannerModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerResource
 
put(TableSchemaModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
 
put(Runnable) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
put(ByteBuffer, TPut, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
put(ByteBuffer, TPut, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
put(ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
put(ByteBuffer, TPut) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Commit a TPut to a table.
put(TPut) - Static method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
put(ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
put(K, V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
put(int, byte) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
put(byte) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
put(byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
put(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
put(int, byte) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
put(E) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
put(int, byte) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store val at index.
put(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store val at index.
put(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store length bytes from val into this range, starting at index.
put(R) - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
put(K, V) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
put(R) - Method in class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
 
put(byte) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store val at the next position in this range.
put(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store the content of val in this range, starting at the next position.
put(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store length bytes from val into this range.
put(int, byte) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
put(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
put(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
put(byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
put(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
put(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
put(byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
put(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
put(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
PUT_BATCH_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
PUT_BATCH_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
 
PUT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
PUT_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
 
putAll(Map<Field, FieldValue>) - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
 
putAll(Map<? extends Field, ? extends FieldValue>) - Method in class org.apache.hadoop.hbase.hbtop.Record
 
putAll(Map<? extends byte[], ? extends byte[]>) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
putAsShort(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put an int value as short out to the specified byte array position.
putBack(Cell) - Method in class org.apache.hadoop.hbase.rest.ResultGenerator
 
putBack(Cell) - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
 
putBack(Cell) - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
putBigDecimal(byte[], int, BigDecimal) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a BigDecimal value out to the specified byte array position.
putBinary(byte[], UriInfo, HttpHeaders) - Method in class org.apache.hadoop.hbase.rest.RowResource
 
putBuffer(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.BoundedByteBufferPool
 
putByte(byte[], int, byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write a single byte out to the specified byte array position.
putByteBuffer(byte[], int, ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
Add the whole content of the ByteBuffer to the bytes arrays.
putBytes(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put bytes at the specified byte array position.
putChar(int, int, char, Attributes) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
 
PutCombiner<K> - Class in org.apache.hadoop.hbase.mapreduce
Combine Puts.
PutCombiner() - Constructor for class org.apache.hadoop.hbase.mapreduce.PutCombiner
 
putCompressedInt(OutputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Put in buffer integer using 7 bit encoding.
putDouble(byte[], int, double) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
putFloat(byte[], int, float) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
putFromThrift(TPut) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
Creates a Put (HBase) from a TPut (Thrift)
putIfAbsent(K, V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
putInt(int, int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
putInt(int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
putInt(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
putInt(OutputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Put in output stream 32 bit integer (Big Endian byte order).
putInt(int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store the int value at index
putInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put an int value out to the specified byte array position.
putInt(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store int val at the next position in this range.
putInt(int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
putInt(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putInt(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putIntUnsafe(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put an int value out to the specified byte array position (Unsafe).
putLong(int, long) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
putLong(int, long) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
putLong(long) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
putLong(OutputStream, long, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
 
putLong(int, long) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store the long value at index
putLong(byte[], int, long) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a long value out to the specified byte array position.
putLong(long) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store long val at the next position in this range.
putLong(int, long) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
putLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putLongUnsafe(byte[], int, long) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a long value out to the specified byte array position (Unsafe).
putMultiple(ByteBuffer, List<TPut>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
putMultiple(ByteBuffer, List<TPut>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
putMultiple(ByteBuffer, List<TPut>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
putMultiple(ByteBuffer, List<TPut>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Commit a List of Puts to the table.
putMultiple(ByteBuffer, List<TPut>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
putMultiple(long, int, byte[]) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
Transfers bytes from the given source array into this buffer array
putMultiple(long, int, byte[], int) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
Transfers bytes from the given source array into this buffer array
putNoBody(byte[], UriInfo, HttpHeaders) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
Build a response for PUT alter namespace with no properties specified.
putsFromThrift(List<TPut>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
Converts multiple TPuts (Thrift) into a list of Puts (HBase).
putShort(int, short) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
putShort(int, short) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
putShort(short) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
putShort(int, short) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store the short value at index
putShort(byte[], int, short) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a short value out to the specified byte array position.
putShort(short) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store short val at the next position in this range.
putShort(int, short) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
putShort(short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putShort(short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putShortUnsafe(byte[], int, short) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put a short value out to the specified byte array position (Unsafe).
PutSortReducer - Class in org.apache.hadoop.hbase.mapreduce
Emits sorted Puts.
PutSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.PutSortReducer
 
putsToMetaTable(Connection, List<Put>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Put the passed ps to the hbase:meta table.
putString(int, int, String, Attributes) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
 
putTable(HTableInterface) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated. 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
putToAttributes(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
putToColFamTimeRangeMap(ByteBuffer, TTimeRange) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
putToColumns(ByteBuffer, TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
putToSuccess(ByteBuffer, ColumnDescriptor) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
putTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
putVLong(long) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
putVLong(int, long) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Store the long value at index as a VLong
putVLong(long) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Store the long val at the next position as a VLong
putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
putVLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
putVLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 

Q

QOS_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
 
QosPriority - Annotation Type in org.apache.hadoop.hbase.ipc
Annotation which decorates RPC methods to denote the relative priority among other RPCs in the same server.
qualifier - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
qualifier - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
qualifier - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
qualifier - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
column qualifier to check
qualifier - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
column qualifier to check
qualifier - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
column qualifier to check
qualifierBuffer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
qualifierDeduplicator - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
QualifierFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on the column qualifier.
QualifierFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.QualifierFilter
Constructor.
qualifierLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
qualifierOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
qualifierOffsetsOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
qualifierOffsetWidth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
qualifierRange - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
qualifierReader - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
qualifierTokenizer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
qualifierWriter - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
qualifyMetricsName(TableName, String) - Static method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
quantile - Variable in class org.apache.hadoop.metrics2.util.MetricQuantile
 
Query - Class in org.apache.hadoop.hbase.client
 
Query() - Constructor for class org.apache.hadoop.hbase.client.Query
 
QUEUE_CALL_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
QUEUE_CALL_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
QUEUE_MAX_CALL_DELAY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
max delay in msec used to bound the deprioritized requests
QUEUE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
QUEUE_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
queuedAndProcessedCall(int) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
queuedAndProcessedCall(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
queueIncrement(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
queueIncrements(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
queues - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
queuesZNode - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the znode that contains all replication queues
QUORUM_ADDRESS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Optional job parameter to specify a peer cluster.
QUORUM_PORT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Optional job parameter to specify peer cluster's ZK client port
QUOTA_CONF_KEY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
QUOTA_FAMILY_INFO - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_FAMILY_USAGE - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_NAMESPACE_ROW_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_QUALIFIER_SETTINGS - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_QUALIFIER_SETTINGS_PREFIX - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_RATE_LIMITER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.quotas.RateLimiter
 
QUOTA_TABLE_DESC - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
Table descriptor for Quota internal table
QUOTA_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
System table for quotas
QUOTA_TABLE_ROW_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QUOTA_USER_ROW_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QuotaCache - Class in org.apache.hadoop.hbase.quotas
Cache that keeps track of the quota settings for the users and tables that are interacting with it.
QuotaCache(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.quotas.QuotaCache
 
QuotaExceededException - Exception in org.apache.hadoop.hbase.quotas
Generic quota exceeded exception
QuotaExceededException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.QuotaExceededException
 
QuotaFilter - Class in org.apache.hadoop.hbase.quotas
Filter to use to filter the QuotaRetriever results.
QuotaFilter() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaFilter
 
QuotaLimiter - Interface in org.apache.hadoop.hbase.quotas
Internal interface used to interact with the user/table quota.
QuotaLimiterFactory - Class in org.apache.hadoop.hbase.quotas
 
QuotaRetriever - Class in org.apache.hadoop.hbase.quotas
Scanner to iterate over the quota settings.
QuotaScope - Enum in org.apache.hadoop.hbase.quotas
Describe the Scope of the quota rules.
QuotaSettings - Class in org.apache.hadoop.hbase.quotas
 
QuotaSettings(String, TableName, String) - Constructor for class org.apache.hadoop.hbase.quotas.QuotaSettings
 
QuotaSettingsFactory - Class in org.apache.hadoop.hbase.quotas
 
quotasFromData(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QuotaState - Class in org.apache.hadoop.hbase.quotas
In-Memory state of table or namespace quotas
QuotaState() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaState
 
QuotaState(long) - Constructor for class org.apache.hadoop.hbase.quotas.QuotaState
 
quotasToData(QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QuotaTableUtil - Class in org.apache.hadoop.hbase.quotas
Helper class to interact with the quota table.
QuotaTableUtil() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
QuotaTableUtil.NamespaceQuotasVisitor - Interface in org.apache.hadoop.hbase.quotas
 
QuotaTableUtil.QuotasVisitor - Interface in org.apache.hadoop.hbase.quotas
 
QuotaTableUtil.TableQuotasVisitor - Interface in org.apache.hadoop.hbase.quotas
 
QuotaTableUtil.UserQuotasVisitor - Interface in org.apache.hadoop.hbase.quotas
 
QuotaType - Enum in org.apache.hadoop.hbase.quotas
Describe the Quota Type.
QuotaUtil - Class in org.apache.hadoop.hbase.quotas
Helper class to interact with the quota table
QuotaUtil() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaUtil
 
quote(String) - Static method in class org.apache.hadoop.hbase.security.visibility.CellVisibility
Helps in quoting authentication Strings.
quote(byte[]) - Static method in class org.apache.hadoop.hbase.security.visibility.CellVisibility
Helps in quoting authentication Strings.
quoteHtmlChars(OutputStream, byte[], int, int) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
Quote all of the active HTML characters in the given string as they are added to the buffer.
quoteHtmlChars(String) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
Quote the given item to make it html-safe.
quoteOutputStream(OutputStream) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
Return an output stream that quotes all of the output.

R

R - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'R'
rackManager - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
 
rackManager - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
RackManager - Class in org.apache.hadoop.hbase.master
Wrapper over the rack resolution utility in Hadoop.
RackManager() - Constructor for class org.apache.hadoop.hbase.master.RackManager
 
RackManager(Configuration) - Constructor for class org.apache.hadoop.hbase.master.RackManager
 
random - Static variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
random(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Fill given array with random bytes.
random(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Fill given array with random bytes at the specified position.
Random64 - Class in org.apache.hadoop.hbase.util
An instance of this class is used to generate a stream of pseudorandom numbers.
Random64() - Constructor for class org.apache.hadoop.hbase.util.Random64
 
Random64(long) - Constructor for class org.apache.hadoop.hbase.util.Random64
 
randomAssignment(HRegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Used to assign a single region to a random server.
randomAssignment(HRegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
 
randomAssignment(HRegionInfo, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Get a random region server from the list
randomAssignment(HRegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
RandomRowFilter - Class in org.apache.hadoop.hbase.filter
A filter that includes rows based on a chance.
RandomRowFilter(float) - Constructor for class org.apache.hadoop.hbase.filter.RandomRowFilter
Create a new filter with a specified chance for a row to be included.
RateLimiter - Class in org.apache.hadoop.hbase.quotas
Simple rate limiter.
RateLimiter() - Constructor for class org.apache.hadoop.hbase.quotas.RateLimiter
 
RatioBasedCompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
The default algorithm for selecting files for compaction.
RatioBasedCompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
 
raw() - Method in class org.apache.hadoop.hbase.client.Result
Deprecated.
as of 0.96, use Result.rawCells()
RAW_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
Needed for Bloom Filters.
RawByte - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.putByte(byte[], int, byte).
RawByte() - Constructor for class org.apache.hadoop.hbase.types.RawByte
 
RawBytes - Class in org.apache.hadoop.hbase.types
An DataType for interacting with variable-length values encoded using Bytes.putBytes(byte[], int, byte[], int, int).
RawBytes() - Constructor for class org.apache.hadoop.hbase.types.RawBytes
 
RawBytes(Order) - Constructor for class org.apache.hadoop.hbase.types.RawBytes
 
RawBytesFixedLength - Class in org.apache.hadoop.hbase.types
An DataType that encodes fixed-length values encoded using Bytes.putBytes(byte[], int, byte[], int, int).
RawBytesFixedLength(Order, int) - Constructor for class org.apache.hadoop.hbase.types.RawBytesFixedLength
Create a RawBytesFixedLength using the specified order and length.
RawBytesFixedLength(int) - Constructor for class org.apache.hadoop.hbase.types.RawBytesFixedLength
Create a RawBytesFixedLength of the specified length.
RawBytesTerminated - Class in org.apache.hadoop.hbase.types
An DataType that encodes variable-length values encoded using Bytes.putBytes(byte[], int, byte[], int, int).
RawBytesTerminated(Order, byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
Create a RawBytesTerminated using the specified terminator and order.
RawBytesTerminated(Order, String) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
Create a RawBytesTerminated using the specified terminator and order.
RawBytesTerminated(byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
Create a RawBytesTerminated using the specified terminator.
RawBytesTerminated(String) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
Create a RawBytesTerminated using the specified terminator.
rawCells() - Method in class org.apache.hadoop.hbase.client.Result
Return the array of Cells backing this Result instance.
RawDouble - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.putDouble(byte[], int, double).
RawDouble() - Constructor for class org.apache.hadoop.hbase.types.RawDouble
 
RawFloat - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.putFloat(byte[], int, float).
RawFloat() - Constructor for class org.apache.hadoop.hbase.types.RawFloat
 
RawInteger - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.putInt(byte[], int, int).
RawInteger() - Constructor for class org.apache.hadoop.hbase.types.RawInteger
 
RawLong - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.putLong(byte[], int, long).
RawLong() - Constructor for class org.apache.hadoop.hbase.types.RawLong
 
RawScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
Query matcher for raw scan.
RawScanQueryMatcher(Scan, ScanInfo, ColumnTracker, boolean, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
 
RawShort - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.putShort(byte[], int, short).
RawShort() - Constructor for class org.apache.hadoop.hbase.types.RawShort
 
RawString - Class in org.apache.hadoop.hbase.types
An DataType for interacting with values encoded using Bytes.toBytes(String).
RawString() - Constructor for class org.apache.hadoop.hbase.types.RawString
 
RawString(Order) - Constructor for class org.apache.hadoop.hbase.types.RawString
 
RawStringFixedLength - Class in org.apache.hadoop.hbase.types
An DataType that encodes fixed-length values encoded using Bytes.toBytes(String).
RawStringFixedLength(Order, int) - Constructor for class org.apache.hadoop.hbase.types.RawStringFixedLength
Create a RawStringFixedLength using the specified order and length.
RawStringFixedLength(int) - Constructor for class org.apache.hadoop.hbase.types.RawStringFixedLength
Create a RawStringFixedLength of the specified length.
RawStringTerminated - Class in org.apache.hadoop.hbase.types
An DataType that encodes variable-length values encoded using Bytes.toBytes(String).
RawStringTerminated(Order, byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
Create a RawStringTerminated using the specified terminator and order.
RawStringTerminated(Order, String) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
Create a RawStringTerminated using the specified terminator and order.
RawStringTerminated(byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
Create a RawStringTerminated using the specified terminator.
RawStringTerminated(String) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
Create a RawStringTerminated using the specified terminator.
REACHED_BARRIER_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
reachedZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
read() - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
Reads the next byte of data from this input stream.
read(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
Reads up to next len bytes of data from buffer into passed array(starting from given offset).
read() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
read(byte[]) - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
read(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
read(long, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
Read bytes starting from the specified position.
read(DataInputStream) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
 
read(ByteBuffer) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
 
read(ByteBuffer, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
Transfers data from the buffer array to the given byte buffer
read(ByteBuffer, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
Transfers data from file to the given byte buffer
read(ByteBuffer, long) - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
Transfers data from IOEngine to the given byte buffer
read() - Method in class org.apache.hadoop.hbase.io.LimitInputStream
 
read(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.LimitInputStream
 
read(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.Reference
Read a Reference from FileSystem.
read(Configuration, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
 
read(ProcedureWALFile, ProcedureWALFormat.Loader) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
 
read() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
 
read(byte[]) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
 
read(byte[], int, int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
 
read(DataInput) - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
Read from in
read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
read() - Method in class org.apache.hadoop.hbase.util.Base64.Base64InputStream
Reads enough of the input stream to convert to/from Base64 and returns the next byte.
read(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Base64.Base64InputStream
Calls Base64.Base64InputStream.read() repeatedly until the end of stream is reached or len bytes are read.
READ_LOCK_CHILD_NODE_PREFIX - Static variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
ZNode prefix used by processes acquiring reader locks
READ_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
READ_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
READ_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
READ_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
READ_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
READ_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
READ_REQUEST_RATE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
READ_REQUEST_RATE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
readAndCheck(DataInputStream) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
Reads a magic record of the length BlockType.MAGIC_LENGTH from the given stream and expects it to match this block type.
readAndCheck(ByteBuffer) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
Reads a magic record of the length BlockType.MAGIC_LENGTH from the given byte buffer and expects it to match this block type.
readAndProcess() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
Read off the wire.
readAsInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an int value
readAsVLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Reads a zero-compressed encoded long from input buffer and returns it.
readBlock(long, long, boolean, boolean, boolean, boolean, BlockType, DataBlockEncoding) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader
Read in a file block.
readBlock(long, long, boolean, boolean, boolean, boolean, BlockType, DataBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
readByteArray(DataInput) - Static method in class org.apache.hadoop.hbase.util.Bytes
Read byte-array written with a WritableableUtils.vint prefix.
readByteArrayThrowsRuntime(DataInput) - Static method in class org.apache.hadoop.hbase.util.Bytes
Read byte-array written with a WritableableUtils.vint prefix.
readClusterIdZNode(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
readCompressedInt(InputStream) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Read integer from stream coded in 7 bits and increment position.
readCompressedInt(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Read integer from buffer coded in 7 bits and increment position.
readEntry(InputStream) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
 
reader - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
reader - Variable in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
ReaderBase - Class in org.apache.hadoop.hbase.regionserver.wal
 
ReaderBase() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
Default constructor.
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Writables are going away. Use pb HColumnDescriptor.parseFrom(byte[]) instead.
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Use protobuf deserialization instead.
readFields(DataInput) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Writables are going away. Use pb HTableDescriptor.parseFrom(byte[]) instead.
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.Reference
Deprecated.
Writables are going away. Use the pb serialization methods instead. Remove in a release after 0.96 goes out. This is here only to migrate old Reference files written with Writables before 0.96.
readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Reads the values of each field.
readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.Permission
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.UserPermission
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
readFieldsFromPb(WALProtos.WALKey, WALCellCodec.ByteStringUncompressor) - Method in class org.apache.hadoop.hbase.wal.WALKey
 
readFrom(InputStream) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
readFrom(Class<ProtobufMessageHandler>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class org.apache.hadoop.hbase.rest.provider.consumer.ProtobufMessageBodyConsumer
 
readFromCells(Codec.Decoder, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
Reads WALEdit from cells.
readFromStream(FSDataInputStream, long) - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
Reads a file trailer from the given file.
readHeader(InputStream) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
 
readHeader(WALProtos.WALHeader.Builder, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
readHeader(WALProtos.WALHeader.Builder, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
 
readKeyValueLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
readKeyValueLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
 
readLabelsFromZKData(byte[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
Reads back from the zookeeper.
readLock(byte[]) - Method in interface org.apache.hadoop.hbase.InterProcessReadWriteLock
Obtain a read lock containing given metadata.
readLock(TableName, String) - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
 
readLock(TableName, String) - Method in class org.apache.hadoop.hbase.master.TableLockManager
Returns a TableLock for locking the table for shared access among read-lock holders
readLock(byte[]) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessReadWriteLock
Obtain a read lock containing given metadata.
readLong(InputStream) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
 
readLong(InputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Read long which was written to fitInBytes bytes and increment position.
readLong(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Read long which was written to fitInBytes bytes and increment position.
readMultiLevelIndexRoot(HFileBlock, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
Read the root-level metadata of a multi-level block index.
readMvccVersion(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
Read mvcc.
readMvccVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
readMyEphemeralNodeOnDisk() - Static method in class org.apache.hadoop.hbase.ZNodeClearer
read the content of znode file, expects a single line.
readNext(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
readNext(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
Read next entry.
readNext(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
fill in the passed entry with teh next key/value.
readNextDataBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
Scans blocks in the "scanned" section of the HFile until the next data block is found.
readOlderScopes(NavigableMap<byte[], Integer>) - Method in class org.apache.hadoop.hbase.wal.WALKey
 
READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by rest interface to access this metadata attribute which denotes if the table is Read Only
readOnly() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
Is this operation read only? If this is true, process() should not add any mutations or it throws IOException.
READONLY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
ReadOnlyByteRangeException - Exception in org.apache.hadoop.hbase.util
Exception thrown when a read only byte range is modified
ReadOnlyByteRangeException() - Constructor for exception org.apache.hadoop.hbase.util.ReadOnlyByteRangeException
 
readPermissions(byte[], Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
Reads a set of permissions as Writable instances from the input stream.
readRawVarint32(InputStream) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
 
readRawVarint32(ByteBuffer) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
 
readRawVarint32(byte[], int) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
Reads a varInt value stored in an array.
readRawVarint32(DataInput) - Static method in class org.apache.hadoop.hbase.util.ProtoUtil
Read a variable length integer in the same format that ProtoBufs encodes.
READREQUESTSCOUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
readRootIndex(DataInput, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
Read in the root-level index from the given input stream.
readRootIndex(HFileBlock, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
Read in the root-level index from the given input stream.
readSnapshotInfo(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Read in the HBaseProtos.SnapshotDescription stored for the snapshot in the passed directory
readStringFixedSize(DataInput, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Reads a fixed-size field and interprets it as a string padded with zeros.
readTimestamp(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffCompressionState
 
readTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
readTracker(ProcedureStoreTracker) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
readTrailer() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
readTrailer(FSDataInputStream, long, long) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
 
readUserAuthsFromZKData(byte[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
Reads back User auth data written to zookeeper.
readVariableBytesFromArray(byte[], int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
readVariableBytesFromInputStream(InputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
readVLong(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Similar to WritableUtils.readVLong(DataInput) but reads from a ByteBuffer.
readVLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Deprecated.
since 0.98.12. Use Bytes.readAsVLong(byte[],int) instead.
readZKNodes(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKServerTool
 
reallocate(int, int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
 
realSeekDone() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
We optimize our store scanners by checking the most recent store file first, so we sometimes pretend we have done a seek but delay it until the store scanner bubbles up to the top of the key-value heap.
realSeekDone() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
 
realSeekDone() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
reapAllExpiredLocks() - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
 
reapAllExpiredLocks() - Method in class org.apache.hadoop.hbase.master.TableLockManager
Force releases all table locks(read and write) that have been held longer than "hbase.table.lock.expire.ms".
reapAllLocks() - Method in interface org.apache.hadoop.hbase.InterProcessLock
If supported, attempts to reap all the locks of this type by forcefully deleting the locks (both held and attempted).
reapAllLocks() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
 
reapExpiredLocks(long) - Method in interface org.apache.hadoop.hbase.InterProcessLock
If supported, attempts to reap all the locks of this type by forcefully deleting the locks (both held and attempted) that have expired according to the given timeout.
reapExpiredLocks(long) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Will delete all lock znodes of this type (either read or write) which are "expired" according to timeout.
reapWriteLocks() - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
 
reapWriteLocks() - Method in class org.apache.hadoop.hbase.master.TableLockManager
Force releases table write locks and lock attempts even if this thread does not own the lock.
REASSIGN_WAIT_INTERVAL_KEY - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
 
rebuildMeta(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Rebuilds meta from information in hdfs/fs.
receive(ForeignException) - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
 
receive(ForeignException) - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionListener
Receive a ForeignException.
receive(ForeignException) - Method in class org.apache.hadoop.hbase.procedure.Procedure
A callback that handles incoming ForeignExceptions.
receiveAbortProcedure(String, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
Send abort to the specified procedure
RECEIVED_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
RECEIVED_BYTES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
receivedBytes(int) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
receivedBytes(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
receivedReachedGlobalBarrier(String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
Notification that procedure coordinator has reached the global barrier
receivedRequest(long) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
receivedRequest(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
receiveReachedGlobalBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
Callback for the member rpcs to call when the global barrier has been reached.
reconnect(KeeperException) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
A private method used to re-establish a zookeeper session with a peer cluster.
reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
reconstruct(PrefixTreeBlockMeta, Tokenizer, ColumnNodeType) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
 
reconstruct(PrefixTreeEncoder, TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
reconstruct(PrefixTreeEncoder) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
reconstruct(Tokenizer, TokenizerNode, int, int, int, int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
Record - Class in org.apache.hadoop.hbase.hbtop
Represents a record of the metrics in the top screen.
Record.Builder - Class in org.apache.hadoop.hbase.hbtop
 
Record.Entry - Class in org.apache.hadoop.hbase.hbtop
 
RecordFilter - Class in org.apache.hadoop.hbase.hbtop
Represents a filter that's filtering the metric Records.
RecordFilter.FilterBuilder - Class in org.apache.hadoop.hbase.hbtop
 
RecoverableZooKeeper - Class in org.apache.hadoop.hbase.zookeeper
A zookeeper that can handle 'recoverable' errors.
RecoverableZooKeeper(String, int, Watcher, int, int, int) - Constructor for class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
RecoverableZooKeeper(String, int, Watcher, int, int, int, String) - Constructor for class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
RECOVERED_EDITS_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
 
recoverFileLease(FileSystem, Path) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.WALStoreLeaseRecovery
 
recoverFileLease(FileSystem, Path) - Method in interface org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.LeaseRecovery
 
recoverFileLease(FileSystem, Path, Configuration, CancelableProgressable) - Method in class org.apache.hadoop.hbase.util.FSHDFSUtils
Recover the lease from HDFS, retrying multiple times.
recoverFileLease(FileSystem, Path, Configuration, CancelableProgressable) - Method in class org.apache.hadoop.hbase.util.FSMapRUtils
 
recoverFileLease(FileSystem, Path, Configuration, CancelableProgressable) - Method in class org.apache.hadoop.hbase.util.FSUtils
Recover file lease.
recoveringRegionLock - Variable in class org.apache.hadoop.hbase.master.SplitLogManager
In distributedLogReplay mode, we need touch both splitlog and recovering-regions znodes in one operation.
recoveringRegions - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
Set of regions currently being in recovering state which means it can accept writes(edits from previous failed region server) but not reads.
recoveringRegionsZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
RecoveringRegionWatcher - Class in org.apache.hadoop.hbase.zookeeper
Watcher used to be notified of the recovering region coming out of recovering state
RecoveringRegionWatcher(ZooKeeperWatcher, HRegionServer) - Constructor for class org.apache.hadoop.hbase.zookeeper.RecoveringRegionWatcher
Construct a ZooKeeper event listener.
recoverLease() - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
 
recoverLease() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
Acquire the lease for the procedure store.
recoverLease() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
recv_append() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_append() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_atomicIncrement() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_checkAndDelete() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_checkAndMutate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_checkAndPut() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_checkAndPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_closeScanner() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_compact() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_createTable() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_deleteAll() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_deleteAllRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_deleteAllRowTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_deleteAllTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_deleteMultiple() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_deleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_deleteTable() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_disableTable() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_enableTable() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_exists() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_existsAll() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_get() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_get() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_getAllRegionLocations() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_getColumnDescriptors() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getMultiple() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_getRegionInfo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getRegionLocation() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getRowOrBefore() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getRowsTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getRowsWithColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getRowsWithColumnsTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getRowTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getRowWithColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getRowWithColumnsTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getScannerResults() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_getScannerRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_getTableNames() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getTableRegions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getVer() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_getVerTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_increment() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_increment() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_incrementRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_isTableEnabled() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_majorCompact() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_mutateRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_mutateRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_mutateRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_mutateRowsTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_mutateRowTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_openScanner() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_put() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_putMultiple() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_scannerClose() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerGet() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerGetList() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerOpen() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerOpenTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerOpenWithPrefix() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerOpenWithScan() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerOpenWithStop() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
recv_scannerOpenWithStopTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
reduce(Stack<ByteBuffer>, Stack<Filter>, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
This function is called while parsing the filterString and an operator is parsed
reduce(ImmutableBytesWritable, Iterator<Put>, OutputCollector<ImmutableBytesWritable, Put>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IdentityTableReduce
No aggregation, output pairs of (key, record)
reduce(Writable, Iterable<Mutation>, Reducer<Writable, Mutation, Writable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
Writes each given record, consisting of the row key and the given values, to the configured OutputFormat.
reduce(Import.KeyValueWritableComparable, Iterable<KeyValue>, Reducer<Import.KeyValueWritableComparable, KeyValue, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueReducer
 
reduce(ImmutableBytesWritable, Iterable<KeyValue>, Reducer<ImmutableBytesWritable, KeyValue, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSortReducer
 
reduce(K, Iterable<Put>, Reducer<K, Put, K, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutCombiner
 
reduce(ImmutableBytesWritable, Iterable<Put>, Reducer<ImmutableBytesWritable, Put, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutSortReducer
 
reduce(ImmutableBytesWritable, Iterable<Text>, Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
REENTRANT_LOCK - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ReentrantReadWriteLock
Reference - Class in org.apache.hadoop.hbase.io
A reference to the top or bottom half of a store file where 'bottom' is the first half of the file containing the keys that sort lowest and 'top' is the second half of the file with keys that sort greater than those of the bottom half.
Reference() - Constructor for class org.apache.hadoop.hbase.io.Reference
Deprecated.
need by pb serialization
REFERENCE - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Reference size is 8 bytes on 64-bit, 4 bytes on 32-bit
refill(long) - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
 
refill(long) - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
 
ReflectionUtils - Class in org.apache.hadoop.hbase.util
 
ReflectionUtils() - Constructor for class org.apache.hadoop.hbase.util.ReflectionUtils
 
refresh(long, long, long) - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
 
refresh(boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
refresh() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
refresh() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
 
refresh() - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Refresh/reload the group information from the persistent store
refresh() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
REFRESH_CONF_KEY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaCache
 
refreshAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
Refreshing the age makes sure the value returned is the actual one and not the one set a replication time
refreshAgeOfLastShippedOp(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Convenience method to use the last given timestamp to refresh the age of the last edit.
refreshAndGetReplicationLoad() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
Refresh and Get ReplicationLoad
refreshAndGetReplicationLoad() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
refreshAuthManager(PolicyProvider) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
refreshAuthManager(PolicyProvider) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
Refresh authentication manager policy.
refreshHFiles(TableName) - Method in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
 
refreshHFiles(Table) - Method in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
 
refreshHFiles(RpcController, RefreshHFilesProtos.RefreshHFilesRequest, RpcCallback<RefreshHFilesProtos.RefreshHFilesResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.RefreshHFilesEndpoint
 
RefreshHFilesClient - Class in org.apache.hadoop.hbase.client.example
This client class is for invoking the refresh HFile function deployed on the Region Server side via the RefreshHFilesService.
RefreshHFilesClient(Configuration) - Constructor for class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
Constructor with Conf object
RefreshHFilesEndpoint - Class in org.apache.hadoop.hbase.coprocessor.example
Coprocessor endpoint to refresh HFiles on replica.
RefreshHFilesEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.RefreshHFilesEndpoint
 
refreshLabelsCache(byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
 
refreshMetricsData() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
refreshNamespaceCacheFromWritable(String, byte[]) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
refreshStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
refreshStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
Checks the underlying store files, and opens the files that have not been opened, and removes the store file readers for store files no longer available.
refreshStoreFiles(Collection<String>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
refreshStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Region
Check the region's underlying store files, open the files that have not been opened yet, and remove the store file readers for store files no longer available.
refreshStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
Checks the underlying store files, and opens the files that have not been opened, and removes the store file readers for store files no longer available.
refreshStoreFiles(Collection<String>) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Replaces the store files that the store has with the given files.
refreshTableCacheFromWritable(TableName, byte[]) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
refreshTerminal() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
refreshUserAuthsCache(byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
 
regex - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
 
RegexStringComparator - Class in org.apache.hadoop.hbase.filter
This comparator is for use with CompareFilter implementations, such as RowFilter, QualifierFilter, and ValueFilter, for filtering based on the value of a given column.
RegexStringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor Adds Pattern.DOTALL to the underlying Pattern
RegexStringComparator(String, RegexStringComparator.EngineType) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor Adds Pattern.DOTALL to the underlying Pattern
RegexStringComparator(String, int) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor
RegexStringComparator(String, int, RegexStringComparator.EngineType) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor
RegexStringComparator.EngineType - Enum in org.apache.hadoop.hbase.filter
Engine implementation type (default=JAVA)
regexStringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
RegexStringType byte array
region - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.AssignRegionAction
 
region - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.MoveRegionAction
 
region - Variable in class org.apache.hadoop.hbase.regionserver.FlushPolicy
The region configured for this flush policy.
Region - Interface in org.apache.hadoop.hbase.regionserver
Regions store data for a certain region of a table.
region - Variable in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
The region configured for this split policy.
Region.BulkLoadListener - Interface in org.apache.hadoop.hbase.regionserver
Listener class to enable callers of bulkLoadHFile() to perform any necessary pre/post processing of a given bulkload call
Region.FlushResult - Interface in org.apache.hadoop.hbase.regionserver
 
Region.FlushResult.Result - Enum in org.apache.hadoop.hbase.regionserver
 
Region.Operation - Enum in org.apache.hadoop.hbase.regionserver
Operation enum is used in Region.startRegionOperation() to provide context for various checks before any region operation begins.
Region.RowLock - Interface in org.apache.hadoop.hbase.regionserver
Row lock held by a given thread.
REGION_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
REGION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
REGION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
REGION_EVENT - Static variable in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
REGION_GROUPING_STRATEGY - Static variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
REGION_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
 
REGION_INFO_FILE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Name of the region info file that resides just under the region directory.
region_jsp - Class in org.apache.hadoop.hbase.generated.regionserver
 
region_jsp() - Constructor for class org.apache.hadoop.hbase.generated.regionserver.region_jsp
 
REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL flag to indicate whether or not the memstore should be replicated for read-replicas (CONSISTENCY => TIMELINE).
REGION_MERGES_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Temporary subdirectory of the region directory used for merges.
REGION_REPLICA_REPLICATION_CONF_KEY - Static variable in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
Whether asynchronous WAL replication to the secondary region replicas is enabled or not.
REGION_REPLICA_STORE_FILE_REFRESH - Static variable in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
Enables or disables refreshing store files of secondary region replicas when the memory is above the global memstore lower limit.
REGION_REPLICA_STORE_FILE_REFRESH_MEMSTORE_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
The multiplier to use when we want to refresh a secondary region instead of flushing a primary region.
REGION_REPLICA_WAIT_FOR_PRIMARY_FLUSH_CONF_KEY - Static variable in class org.apache.hadoop.hbase.client.RegionReplicaUtil
Whether or not the secondary region will wait for observing a flush / region open event from the primary region via async wal replication before enabling read requests.
REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL number of region replicas for the table.
REGION_SERVER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Optional specification of the rs class name of the peer cluster
REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REGION_SERVER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REGION_SERVER_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for what region server implementation to use.
REGION_SERVER_IMPL - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Optional specification of the rs impl name of the peer cluster
REGION_SERVER_REGION_SPLIT_LIMIT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
REGION_SERVER_REPLICATION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REGION_SERVER_RPC_SCHEDULER_FACTORY_CLASS - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
RPC scheduler to use for the region server.
REGION_SPLIT_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
The max number of threads used for splitting storefiles in parallel during the region split process.
REGION_SPLITS_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Temporary subdirectory of the region directory used for splits.
REGION_STATE_COMPARATOR - Static variable in class org.apache.hadoop.hbase.master.RegionStates
 
RegionAdminServiceCallable<T> - Class in org.apache.hadoop.hbase.client
Similar to RegionServerCallable but for the AdminService interface.
RegionAdminServiceCallable(ClusterConnection, RpcControllerFactory, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
RegionAdminServiceCallable(ClusterConnection, RpcControllerFactory, HRegionLocation, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
RegionAdminServiceCallable(ClusterConnection, RpcControllerFactory, HRegionLocation, TableName, byte[], int) - Constructor for class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
RegionAlreadyInTransitionException - Exception in org.apache.hadoop.hbase.regionserver
This exception is thrown when a region server is asked to open or close a region but it's already processing it
RegionAlreadyInTransitionException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionAlreadyInTransitionException
 
regionClosed(HRegionInfo) - Method in interface org.apache.hadoop.hbase.master.AssignmentListener
The region was closed on the region server.
RegionCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
 
RegionCoprocessorHost - Class in org.apache.hadoop.hbase.regionserver
Implements the coprocessor environment and runtime support for coprocessors loaded within a Region.
RegionCoprocessorHost(Region, RegionServerServices, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Constructor
RegionCoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
Provides clients with an RPC connection to call coprocessor endpoint Services against a given table region.
RegionCoprocessorRpcChannel(ClusterConnection, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
 
RegionCoprocessorServiceExec - Class in org.apache.hadoop.hbase.client
Represents a coprocessor service method execution against a single region.
RegionCoprocessorServiceExec(byte[], byte[], Descriptors.MethodDescriptor, Message) - Constructor for class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
regionDict - Variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
 
regionDirPattern - Static variable in class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
 
RegionException - Exception in org.apache.hadoop.hbase
Thrown when something happens related to region handling.
RegionException() - Constructor for exception org.apache.hadoop.hbase.RegionException
default constructor
RegionException(String) - Constructor for exception org.apache.hadoop.hbase.RegionException
Constructor
regionFavoredNodesMap - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
Map of encoded region names to the DataNode locations they should be hosted on We store the value as InetSocketAddress since this is used only in HDFS API (create() that takes favored nodes as hints for placing file blocks).
regionFinder - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
RegionGroupingProvider - Class in org.apache.hadoop.hbase.wal
A WAL Provider that returns a WAL per group of regions.
RegionGroupingProvider() - Constructor for class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
RegionGroupingProvider.RegionGroupingStrategy - Interface in org.apache.hadoop.hbase.wal
Map identifiers to a group number.
regionId - Variable in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
regionInfo - Variable in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
REGIONINFO_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The regioninfo column qualifier
REGIONINFO_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The RegionInfo qualifier as a string
RegionInRecoveryException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when a read request issued against a region which is in recovering state.
RegionInRecoveryException() - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionInRecoveryException
default constructor
RegionInRecoveryException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionInRecoveryException
Constructor
RegionListTmpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
RegionListTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
 
RegionListTmpl(String) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
 
RegionListTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
 
RegionListTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
RegionListTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
 
RegionListTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.regionserver
 
RegionListTmplImpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
RegionListTmplImpl(TemplateManager, RegionListTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmplImpl
 
RegionLoad - Class in org.apache.hadoop.hbase
Encapsulates per-region load metrics.
RegionLoad(ClusterStatusProtos.RegionLoad) - Constructor for class org.apache.hadoop.hbase.RegionLoad
 
regionLoadPB - Variable in class org.apache.hadoop.hbase.RegionLoad
 
regionLocationFromHBase(HRegionLocation) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
 
RegionLocations - Class in org.apache.hadoop.hbase
Container for holding a list of HRegionLocation's that correspond to the same range.
RegionLocations(HRegionLocation...) - Constructor for class org.apache.hadoop.hbase.RegionLocations
Constructs the region location list.
RegionLocations(Collection<HRegionLocation>) - Constructor for class org.apache.hadoop.hbase.RegionLocations
 
regionLocationsFromHBase(List<HRegionLocation>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
 
RegionLocator - Interface in org.apache.hadoop.hbase.client
Used to view region location information for a single HBase table.
regionMaximumEditLogSeqNum - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
regionMaxSeqIdInStores - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
 
RegionMergeCoordination - Interface in org.apache.hadoop.hbase.coordination
Coordination operations for region merge transaction.
regionMergeCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
RegionMergeCoordination.RegionMergeDetails - Interface in org.apache.hadoop.hbase.coordination
Dummy interface for region merge transaction details.
RegionMergeTransaction - Interface in org.apache.hadoop.hbase.regionserver
Executes region merge as a "transaction".
RegionMergeTransaction.JournalEntry - Interface in org.apache.hadoop.hbase.regionserver
Split transaction journal entry
RegionMergeTransaction.RegionMergeTransactionPhase - Enum in org.apache.hadoop.hbase.regionserver
Each enum is a step in the merge transaction.
RegionMergeTransaction.TransactionListener - Interface in org.apache.hadoop.hbase.regionserver
Split transaction listener
RegionMergeTransactionFactory - Class in org.apache.hadoop.hbase.regionserver
A factory for creating RegionMergeTransactions, which execute region split as a "transaction".
RegionMergeTransactionFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionFactory
 
RegionMergeTransactionImpl - Class in org.apache.hadoop.hbase.regionserver
 
RegionMergeTransactionImpl(Region, Region, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
Constructor
RegionMergeTransactionImpl(Region, Region, boolean, long) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
Constructor
RegionMergeTransactionImpl.JournalEntryImpl - Class in org.apache.hadoop.hbase.regionserver
 
RegionMergeTransactionImpl.JournalEntryImpl(RegionMergeTransaction.RegionMergeTransactionPhase) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl.JournalEntryImpl
 
RegionMergeTransactionImpl.JournalEntryImpl(RegionMergeTransaction.RegionMergeTransactionPhase, long) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl.JournalEntryImpl
 
RegionModeStrategy - Class in org.apache.hadoop.hbase.hbtop.mode
Implementation for ModeStrategy for Region Mode.
RegionMovedException - Exception in org.apache.hadoop.hbase.exceptions
Subclass if the server knows the region is now on another server.
RegionMovedException(ServerName, long) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
RegionMovedException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionMovedException
For hadoop.ipc internal call.
regionName - Variable in class org.apache.hadoop.hbase.regionserver.handler.FinishRegionRecoveringHandler
 
RegionNormalizer - Interface in org.apache.hadoop.hbase.master.normalizer
Performs "normalization" of regions on the cluster, making sure that suboptimal choice of split keys doesn't leave cluster in a situation when some regions are substantially larger than others for considerable amount of time.
RegionNormalizerChore - Class in org.apache.hadoop.hbase.master.normalizer
Chore that will call HMaster.normalizeRegions() when needed.
RegionNormalizerChore(HMaster) - Constructor for class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerChore
 
RegionNormalizerFactory - Class in org.apache.hadoop.hbase.master.normalizer
Factory to create instance of RegionNormalizer as configured.
RegionNormalizerTracker - Class in org.apache.hadoop.hbase.zookeeper
Tracks region normalizer state up in ZK
RegionNormalizerTracker(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.RegionNormalizerTracker
 
RegionObserver - Interface in org.apache.hadoop.hbase.coprocessor
Coprocessors implement this interface to observe and mediate client actions on the region.
RegionObserver.MutationType - Enum in org.apache.hadoop.hbase.coprocessor
Mutation type for postMutationBeforeWAL hook
regionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Marks the region as offline.
regionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
regionOffline(HRegionInfo) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Marks the region as offline at balancer.
regionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
A region is offline, won't be in transition any more.
regionOffline(HRegionInfo, RegionState.State) - Method in class org.apache.hadoop.hbase.master.RegionStates
A region is offline, won't be in transition any more.
regionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
RegionOfflineException - Exception in org.apache.hadoop.hbase.client
Thrown when a table can not be located
RegionOfflineException() - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
default constructor
RegionOfflineException(String) - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
 
regionOnline(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
regionOnline(HRegionInfo, ServerName) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Marks the region as online at balancer.
regionOnline(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
regionOnline(HRegionInfo, ServerName, long) - Method in class org.apache.hadoop.hbase.master.RegionStates
A region is online, won't be in transition any more.
regionOnline(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
regionOpened(HRegionInfo, ServerName) - Method in interface org.apache.hadoop.hbase.master.AssignmentListener
The region was opened on the specified server.
RegionOpeningException - Exception in org.apache.hadoop.hbase.exceptions
Subclass if the server knows the region is now on another server.
RegionOpeningException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionOpeningException
 
RegionOpeningState - Enum in org.apache.hadoop.hbase.regionserver
 
RegionPlacementMaintainer - Class in org.apache.hadoop.hbase.master
A tool that is used for manipulating and viewing favored nodes information for regions.
RegionPlacementMaintainer(Configuration) - Constructor for class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
 
RegionPlacementMaintainer(Configuration, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
 
RegionPlacementMaintainer.RandomizedMatrix - Class in org.apache.hadoop.hbase.master
Some algorithms for solving the assignment problem may traverse workers or jobs in linear order which may result in skewing the assignments of the first jobs in the matrix toward the last workers in the matrix if the costs are uniform.
RegionPlacementMaintainer.RandomizedMatrix(int, int) - Constructor for class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
Create a randomization scheme for a matrix of a given size.
RegionPlan - Class in org.apache.hadoop.hbase.master
Stores the plan for the move of an individual region.
RegionPlan(HRegionInfo, ServerName, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionPlan
Instantiate a plan for a region move, moving the specified region from the specified source server to the specified destination server.
RegionPlan.RegionPlanComparator - Class in org.apache.hadoop.hbase.master
 
RegionPlan.RegionPlanComparator() - Constructor for class org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator
 
RegionReplicaFlushHandler - Class in org.apache.hadoop.hbase.regionserver.handler
HBASE-11580: With the async wal approach (HBASE-11568), the edits are not persisted to wal in secondary region replicas.
RegionReplicaFlushHandler(Server, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, int, HRegion) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
 
RegionReplicaReplicationEndpoint - Class in org.apache.hadoop.hbase.replication.regionserver
A ReplicationEndpoint endpoint which receives the WAL edits from the WAL, and sends the edits to replicas of regions.
RegionReplicaReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
 
RegionReplicaUtil - Class in org.apache.hadoop.hbase.client
Utility methods which contain the logic for regions and replicas.
RegionReplicaUtil() - Constructor for class org.apache.hadoop.hbase.client.RegionReplicaUtil
 
REGIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
REGIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
REGIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
REGIONS_SCANNED_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
RegionScanner - Interface in org.apache.hadoop.hbase.regionserver
RegionScanner describes iterators over rows in an HRegion.
regionSequenceIdsToByteArray(Long, Map<byte[], Long>) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
REGIONSERVER - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
region server process name
REGIONSERVER_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
REGIONSERVER_INFO_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
A configuration key for regionserver info port
REGIONSERVER_INFO_PORT_AUTO - Static variable in class org.apache.hadoop.hbase.HConstants
A flag that enables automatic selection of regionserver info port
regionserver_jsp - Class in org.apache.hadoop.hbase.generated.regionserver
 
regionserver_jsp() - Constructor for class org.apache.hadoop.hbase.generated.regionserver.regionserver_jsp
 
REGIONSERVER_META_STOREFILE_REFRESH_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
Whether all storefiles should be refreshed, as opposed to just hbase:meta's Meta region doesn't have WAL replication for replicas enabled yet
REGIONSERVER_METRICS_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
The period (in milliseconds) between computing region server point in time metrics
REGIONSERVER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for port region server listens on.
REGIONSERVER_PROCEDURE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
 
REGIONSERVER_STOREFILE_REFRESH_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
The period (in milliseconds) for refreshing the store files for the secondary regions.
RegionServerAbortedException - Exception in org.apache.hadoop.hbase.regionserver
Thrown by the region server when it is aborting.
RegionServerAbortedException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerAbortedException
 
RegionServerAccounting - Class in org.apache.hadoop.hbase.regionserver
RegionServerAccounting keeps record of some basic real time information about the Region Server.
RegionServerAccounting() - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
 
RegionServerCallable<T> - Class in org.apache.hadoop.hbase.client
Implementations call a RegionServer and implement RetryingCallable.call(int).
RegionServerCallable(Connection, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.client.RegionServerCallable
 
RegionServerCallable(Connection, TableName, byte[], int) - Constructor for class org.apache.hadoop.hbase.client.RegionServerCallable
 
RegionServerCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
 
RegionServerCoprocessorHost - Class in org.apache.hadoop.hbase.regionserver
 
RegionServerCoprocessorHost(RegionServerServices, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
RegionServerCoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
Provides clients with an RPC connection to call coprocessor endpoint Services against a given region server.
RegionServerCoprocessorRpcChannel(ClusterConnection, ServerName) - Constructor for class org.apache.hadoop.hbase.ipc.RegionServerCoprocessorRpcChannel
 
RegionServerFlushTableProcedureManager - Class in org.apache.hadoop.hbase.procedure.flush
This manager class handles flushing of the regions for table on a HRegionServer.
RegionServerFlushTableProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
 
RegionServerFlushTableProcedureManager.FlushTableSubprocedureBuilder - Class in org.apache.hadoop.hbase.procedure.flush
 
RegionServerFlushTableProcedureManager.FlushTableSubprocedureBuilder() - Constructor for class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager.FlushTableSubprocedureBuilder
 
RegionServerListTmpl - Class in org.apache.hadoop.hbase.tmpl.master
 
RegionServerListTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
 
RegionServerListTmpl(String) - Constructor for class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
 
RegionServerListTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
 
RegionServerListTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.master
 
RegionServerListTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
 
RegionServerListTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.master
 
RegionServerListTmplImpl - Class in org.apache.hadoop.hbase.tmpl.master
 
RegionServerListTmplImpl(TemplateManager, RegionServerListTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmplImpl
 
RegionServerModeStrategy - Class in org.apache.hadoop.hbase.hbtop.mode
Implementation for ModeStrategy for RegionServer Mode.
RegionServerObserver - Interface in org.apache.hadoop.hbase.coprocessor
Defines coprocessor hooks for interacting with operations on the HRegionServer process.
RegionServerProcedureManager - Class in org.apache.hadoop.hbase.procedure
A life-cycle management interface for globally barriered procedures on region servers.
RegionServerProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
 
RegionServerProcedureManagerHost - Class in org.apache.hadoop.hbase.procedure
Provides the globally barriered procedure framework and environment for region server oriented operations.
RegionServerProcedureManagerHost() - Constructor for class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
 
RegionServerQuotaManager - Class in org.apache.hadoop.hbase.quotas
Region Server Quota Manager.
RegionServerQuotaManager(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
 
regionServerRemoved(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
 
regionServerRemoved(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationListener
A region server has been removed from the local cluster
regionServerReport(RpcController, RegionServerStatusProtos.RegionServerReportRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
RegionServerRunningException - Exception in org.apache.hadoop.hbase.regionserver
Thrown if the region server log directory exists (which indicates another region server is running at the same address)
RegionServerRunningException() - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
Default Constructor
RegionServerRunningException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
Constructs the exception and supplies a string as the message
RegionServerServices - Interface in org.apache.hadoop.hbase.regionserver
Services provided by HRegionServer
RegionServerServices.PostOpenDeployContext - Class in org.apache.hadoop.hbase.regionserver
Context for postOpenDeployTasks().
RegionServerServices.PostOpenDeployContext(Region, long) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
 
RegionServerServices.RegionStateTransitionContext - Class in org.apache.hadoop.hbase.regionserver
 
RegionServerServices.RegionStateTransitionContext(RegionServerStatusProtos.RegionStateTransition.TransitionCode, long, long, HRegionInfo...) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
 
RegionServerSnapshotManager - Class in org.apache.hadoop.hbase.regionserver.snapshot
This manager class handles the work dealing with snapshots for a HRegionServer.
RegionServerSnapshotManager() - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
 
RegionServerSnapshotManager.SnapshotSubprocedureBuilder - Class in org.apache.hadoop.hbase.regionserver.snapshot
Build the actual snapshot runner that will do all the 'hard' work
RegionServerSnapshotManager.SnapshotSubprocedureBuilder() - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedureBuilder
 
regionServerStartup(RpcController, RegionServerStatusProtos.RegionServerStartupRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
RegionServerStoppedException - Exception in org.apache.hadoop.hbase.regionserver
Thrown by the region server when it is in shutting down state.
RegionServerStoppedException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerStoppedException
 
RegionServerTableMetrics - Class in org.apache.hadoop.hbase.regionserver
Captures operation metrics by table.
RegionServerTableMetrics() - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
RegionServerTracker - Class in org.apache.hadoop.hbase.zookeeper
Tracks the online region servers via ZK.
RegionServerTracker(ZooKeeperWatcher, MasterServices, ServerManager) - Constructor for class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
 
regionsInTransitionInRS - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
RegionSizeCalculator - Class in org.apache.hadoop.hbase.util
Computes size of each region for given table and given column families.
RegionSizeCalculator(HTable) - Constructor for class org.apache.hadoop.hbase.util.RegionSizeCalculator
RegionSizeCalculator(RegionLocator, Admin) - Constructor for class org.apache.hadoop.hbase.util.RegionSizeCalculator
Computes size of each region for table and given column families.
RegionSplitCalculator<R extends KeyRange> - Class in org.apache.hadoop.hbase.util
This is a generic region split calculator.
RegionSplitCalculator(Comparator<R>) - Constructor for class org.apache.hadoop.hbase.util.RegionSplitCalculator
 
RegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
A split policy determines when a region should be split.
RegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
 
RegionSplitter - Class in org.apache.hadoop.hbase.util
The RegionSplitter class provides several utilities to help in the administration lifecycle for developers who choose to manually split regions instead of having HBase handle that automatically.
RegionSplitter() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter
 
RegionSplitter.DecimalStringSplit - Class in org.apache.hadoop.hbase.util
The format of a DecimalStringSplit region boundary is the ASCII representation of reversed sequential number, or any other uniformly distributed decimal value.
RegionSplitter.DecimalStringSplit() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter.DecimalStringSplit
 
RegionSplitter.HexStringSplit - Class in org.apache.hadoop.hbase.util
HexStringSplit is a well-known RegionSplitter.SplitAlgorithm for choosing region boundaries.
RegionSplitter.HexStringSplit() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
 
RegionSplitter.NumberStringSplit - Class in org.apache.hadoop.hbase.util
 
RegionSplitter.SplitAlgorithm - Interface in org.apache.hadoop.hbase.util
A generic interface for the RegionSplitter code to use for all it's functionality.
RegionSplitter.UniformSplit - Class in org.apache.hadoop.hbase.util
A SplitAlgorithm that divides the space of possible keys evenly.
RegionSplitter.UniformSplit() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
RegionsResource - Class in org.apache.hadoop.hbase.rest
 
RegionsResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.RegionsResource
Constructor
RegionState - Class in org.apache.hadoop.hbase.master
State of a Region while undergoing transitions.
RegionState() - Constructor for class org.apache.hadoop.hbase.master.RegionState
 
RegionState(HRegionInfo, RegionState.State) - Constructor for class org.apache.hadoop.hbase.master.RegionState
 
RegionState(HRegionInfo, RegionState.State, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionState
 
RegionState(HRegionInfo, RegionState.State, long, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionState
 
RegionState(HRegionInfo, RegionState.State, long, ServerName, long) - Constructor for class org.apache.hadoop.hbase.master.RegionState
 
RegionState.State - Enum in org.apache.hadoop.hbase.master
 
RegionStateListener - Interface in org.apache.hadoop.hbase
The listener interface for receiving region state events.
RegionStates - Class in org.apache.hadoop.hbase.master
Region state accountant.
RegionStateStore - Class in org.apache.hadoop.hbase.master
A helper to persist region state in meta.
RegionTooBusyException - Exception in org.apache.hadoop.hbase
Thrown by a region server if it will block and wait to serve a request.
RegionTooBusyException() - Constructor for exception org.apache.hadoop.hbase.RegionTooBusyException
default constructor
RegionTooBusyException(String) - Constructor for exception org.apache.hadoop.hbase.RegionTooBusyException
Constructor
RegionTransition - Class in org.apache.hadoop.hbase
Current state of a region in transition.
register(String, Metric) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
register(String, Gauge<T>) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
register(String, String, Object) - Method in interface org.apache.hadoop.hbase.metrics.MBeanSource
Register an mbean with the underlying metrics system
register(String, String, Object) - Method in class org.apache.hadoop.hbase.metrics.MBeanSourceImpl
Register an mbean with the underlying metrics system
register(String, Gauge<T>) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
Register a Gauge.
register(String, Metric) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
Registers the Metric with the given name if there does not exist one with the same name.
register(E) - Method in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
 
register(MetricsRegionSource) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
Register a MetricsRegionSource as being open.
register(MetricsRegionSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
 
register(String, MetricsTableSource) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
Register a MetricsTableSource as being open.
register(String, MetricsTableSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
 
registerAll(MetricSet) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
registerAll(MetricSet) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
Registers the Metrics in the given MetricSet.
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage
 
registerChildren(ConfigurationManager) - Method in interface org.apache.hadoop.hbase.conf.PropagatingConfigurationObserver
Needs to be called to register the children to the manager.
registerChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
Needs to be called to register the children to the manager.
registerChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Needs to be called to register the children to the manager.
registerChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Needs to be called to register the children to the manager.
registerDeserializer(CacheableDeserializer<Cacheable>) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
Register the given cacheable deserializer and generate an unique identifier id for it
registerFilter(String, String) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Register a new filter with the parser.
registerFilters(Configuration) - Static method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
 
registerFilters(Configuration) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftServer
Adds the option to pre-load filters at startup.
registerFlushRequestListener(FlushRequestListener) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
Register a FlushRequestListener
registerForWrite(RpcServer.Connection) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Responder
Add a connection to the list that want to write,
registerListener() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
set the listener for task changes.
registerListener() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
 
registerListener(EventType, EventHandler.EventHandlerListener) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
Subscribe to updates before and after processing instances of EventType.
registerListener(AssignmentListener) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Add the listener to the notification list.
registerListener(ServerListener) - Method in class org.apache.hadoop.hbase.master.ServerManager
Add the listener to the notification list.
registerListener(ProcedureExecutor.ProcedureExecutorListener) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
registerListener(ProcedureStore.ProcedureStoreListener) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
Add the listener to the notification list.
registerListener(ProcedureStore.ProcedureStoreListener) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
 
registerListener(ReplicationListener) - Method in interface org.apache.hadoop.hbase.replication.ReplicationTracker
Register a replication listener to receive replication events.
registerListener(ReplicationListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
 
registerListener(ZooKeeperListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Register the specified listener to receive ZooKeeper events.
registerListenerFirst(ZooKeeperListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Register the specified listener to receive ZooKeeper events and add it as the first in the list of current listeners.
registerMBean(String, String, Object) - Static method in class org.apache.hadoop.hbase.util.MBeanUtil
Register the MBean using our standard MBeanName format "hadoop:service=,name=" Where the and are the supplied parameters
registerNonce(NonceKey) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Register a nonce for a procedure that is going to be submitted.
registerObserver(ConfigurationObserver) - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
Register an observer class
registerService(Service) - Method in class org.apache.hadoop.hbase.master.HMaster
 
registerService(Service) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Registers a new protocol buffer Service subclass as a master coprocessor endpoint.
registerService(Service) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
registerService(Service) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
registerService(Service) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Registers a new protocol buffer Service subclass as a coprocessor endpoint to be available for handling Region.execService(com.google.protobuf.RpcController, org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall)} calls.
registerService(Service) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
Registers a new protocol buffer Service subclass as a coprocessor endpoint to be available for handling
registerTransactionListener(RegionMergeTransaction.TransactionListener) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
Register a listener for transaction preparation, execution, and possibly rollback phases.
registerTransactionListener(RegionMergeTransaction.TransactionListener) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
 
registerTransactionListener(SplitTransaction.TransactionListener) - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
Register a listener for transaction preparation, execution, and possibly rollback phases.
registerTransactionListener(SplitTransaction.TransactionListener) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
 
registerWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
registerWALActionsListener(WALActionsListener) - Method in interface org.apache.hadoop.hbase.wal.WAL
Registers WALActionsListener
registry - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
Note that there are at least 4 MetricRegistry definitions in the source code.
reInitFirstNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
secondary traversal methods
release() - Method in interface org.apache.hadoop.hbase.InterProcessLock
Release the lock.
release() - Method in interface org.apache.hadoop.hbase.master.TableLockManager.TableLock
Release the lock already held.
release() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
 
release() - Method in interface org.apache.hadoop.hbase.regionserver.Region.RowLock
Release the given lock.
release(TableAuthManager) - Static method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Releases the resources for the given TableAuthManager if the reference count is down to 0.
release() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Release the lock.
releaseBarrier() - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
 
releaseBarrier() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
Hooray!
releaseBlockReference() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
Call this before putting the scanner back into a pool so it doesn't hold the last used block in memory.
releaseCurrentSearcher() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
Currently unused.
releaseDelegationToken() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
Releases a previously acquired delegation token.
releaseHTableInterface(HTableInterface) - Method in class org.apache.hadoop.hbase.client.HTableFactory
Deprecated.
 
releaseHTableInterface(HTableInterface) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
Deprecated.
Release the HTable resource represented by the table.
releaseLatch(ProcedurePrepareLatch, Procedure) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
 
releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
releaseLock(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
The user should override this method, and release lock if necessary.
releaseLockEntry(IdLock.Entry) - Method in class org.apache.hadoop.hbase.util.IdLock
Must be called in a finally block to decrease the internal counter and remove the monitor object for the given id if the caller is the last client.
releaseNamespaceExclusiveLock(Procedure, String) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Release the exclusive lock
releaseRowLocks(List<Region.RowLock>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
releaseRowLocks(List<Region.RowLock>) - Method in interface org.apache.hadoop.hbase.regionserver.Region
If the given list of row locks is not null, releases all locks.
releaseServerExclusiveLock(Procedure, ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Release the exclusive lock
releaseServerSharedLock(Procedure, ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Release the shared lock taken
releaseTableExclusiveLock(Procedure, TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Release the exclusive lock taken with tryAcquireTableWrite()
releaseTableLock() - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
releaseTableLock() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
releaseTableSharedLock(Procedure, TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Release the shared lock taken with tryAcquireTableRead()
reload - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
relocateRegion(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Find the location of the region of tableName that row lives in, ignoring any value that might be in the cache.
relocateRegion(TableName, byte[], int) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Find the location of the region of tableName that row lives in, ignoring any value that might be in the cache.
relocateRegion(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
relocateRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
remainingCapacity() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
remainingCapacity() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
remainingCapacity() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
remainingTasksInCoordination() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Return the number of remaining tasks
remainingTasksInCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
REMOTE_RPC_CALLS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
REMOTE_RPC_RETRIES_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
RemoteAdmin - Class in org.apache.hadoop.hbase.rest.client
 
RemoteAdmin(Client, Configuration) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteAdmin
Constructor
RemoteAdmin(Client, Configuration, String) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteAdmin
Constructor
RemoteExceptionHandler - Class in org.apache.hadoop.hbase
An immutable class which contains a static method for handling org.apache.hadoop.ipc.RemoteException exceptions.
RemoteHTable - Class in org.apache.hadoop.hbase.rest.client
HTable interface to remote tables accessed via REST gateway
RemoteHTable(Client, String) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteHTable
Constructor
RemoteHTable(Client, Configuration, String) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteHTable
Constructor
RemoteHTable(Client, Configuration, byte[]) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteHTable
Constructor
remotePort - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
RemoteProcedureException - Exception in org.apache.hadoop.hbase.procedure2
A RemoteProcedureException is an exception from another thread or process.
RemoteProcedureException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
Create a new RemoteProcedureException that can be serialized.
RemoteWithExtrasException - Exception in org.apache.hadoop.hbase.ipc
A RemoteException with some extra information.
RemoteWithExtrasException(String, String, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
RemoteWithExtrasException(String, String, String, int, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
remove(HTableDescriptor) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Remove all Constraints that have been added to the table and turn off the constraint processing.
remove(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Remove the constraint (and associated information) for the table descriptor.
remove(Object) - Method in class org.apache.hadoop.hbase.hbtop.Record
 
remove(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
remove(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Remove metadata represented by the key from the HTableDescriptor.values map
remove(ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Remove metadata represented by the key from the HTableDescriptor.values map
remove(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Remove metadata represented by the key from the HTableDescriptor.values map
remove(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
remove(Object) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
remove() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
remove(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
 
remove(String) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
remove(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
Decrements the ref count of the MetricRegistry, and removes if ref count == 0.
remove(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
Removes the metric with the given name.
remove(E) - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
 
remove(HRegionLocation) - Method in class org.apache.hadoop.hbase.RegionLocations
Removes the given location from the list
remove(int) - Method in class org.apache.hadoop.hbase.RegionLocations
Removes location of the given replicaId from the list
remove(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
remove(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Deletes the mapping for the specified key if it exists.
remove() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
Not supported.
remove(String) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
Remove a node from the cluster
remove(String, int) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
Remove a node from the cluster
remove() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
 
remove() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
remove(TableName) - Method in interface org.apache.hadoop.hbase.TableDescriptors
 
remove() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
remove(Object) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
remove(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
remove(Object, Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
remove() - Method in class org.apache.hadoop.hbase.types.StructIterator
 
remove(Object) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
remove() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
 
remove(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Removes the table descriptor from the local cache and returns it.
remove(R) - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
remove(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
remove(Object) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
remove(Object) - Method in class org.apache.hadoop.hbase.util.SortedList
 
remove(int) - Method in class org.apache.hadoop.hbase.util.SortedList
 
remove(String) - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
 
removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedList
 
removeAllQueues() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Remove all replication queues for this region server.
removeAllQueues() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
removeAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
removeAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
removeByServer(ServerName) - Method in class org.apache.hadoop.hbase.RegionLocations
Returns a new RegionLocations with the locations removed (set to null) which have the destination server as given.
removeChore(ProcedureInMemoryChore) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Remove a chore procedure from the executor
removeClosedRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
When a region is closed, it should be removed from the regionsToReopen
removeColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
removeCompactedFiles(Collection<StoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Remove the compacted files
removeCompactedFiles(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Remove a configuration setting represented by the key from the HColumnDescriptor.configuration map.
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Remove a config setting represented by the key from the HTableDescriptor.configuration map
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
removeConfiguration(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
Remove a config setting represented by the key from the NamespaceDescriptor.configuration map
removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Remove a coprocessor from those set on the table
removeDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
remove the specified dead server
removeExcessFiles(ArrayList<StoreFile>, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
 
removeExtraHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Remove an extra header.
removeFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
removeFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Removes the HColumnDescriptor with name specified by the parameter column from the table descriptor
removeFile() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
removeFromNamespaceUsage(TableName) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
 
removeFromNSTable(String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
removeFromOnlineRegions(Region, ServerName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
removeFromOnlineRegions(Region, ServerName) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
This method removes Region corresponding to hri from the Map of onlineRegions.
removeFromZKNamespaceManager(MasterProcedureEnv, String) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
remove from Zookeeper.
removeFromZKNamespaceManager(String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
removeHFileRefs(String, List<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Remove hfile references from the queue.
removeHFileRefs(String, List<String>) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
removeHFileRefsQueues(Set<String>) - Method in class org.apache.hadoop.hbase.master.cleaner.ReplicationZKNodeCleaner
Remove the undeleted hfile-refs queue's zk node for removed peers.
removeHistogramMetrics(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
 
removeKeyFromZK(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
removeListener() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
remove the listener for task changes.
removeListener() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
 
removeListener(ReplicationPeerConfigListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerConfigTracker
 
removeListener(ReplicationListener) - Method in interface org.apache.hadoop.hbase.replication.ReplicationTracker
 
removeListener(ReplicationListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
 
removeListenerOfPeerConfig(ReplicationPeerConfigListener) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
Remove a listener when it is closed or terminated
removeListenerOfPeerConfig(ReplicationPeerConfigListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
removeLiveNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
removeLog(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Remove an WAL file from the given queue.
removeLog(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
removeMetaData(byte[]) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
removeMetric(String) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Remove a metric and no longer announce it.
removeMetric(String) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
Remove a named gauge.
removeMetric(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
removeMetric(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
removeMetric(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
removeMetric(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Removes metric by name
removeNamespace(byte[]) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
removeNamespaceQuota(MasterProcedureEnv, String) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
remove quota for the namespace
removeNamespaceQuota(String) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
removeNonDefaultRegions(Collection<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
Removes the non-default replicas from the passed regions collection
removeObjectName(String) - Method in class org.apache.hadoop.metrics2.lib.DefaultMetricsSystemHelper
 
removeParentInMeta(Configuration, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
 
removePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Removes a peer cluster and stops the replication to it.
removePeer(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Thie method first deletes all the recovered sources for the specified id, then deletes the normal source (deleting all related data in ZK).
removePeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Removes a remote slave cluster and stops the replication to it.
removePeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
removePeerFromHFileRefs(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Remove a peer from hfile reference queue.
removePeerFromHFileRefs(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
removePeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Remove some table-cfs from table-cfs config of the specified peer
removePeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Remove some table-cfs from config of the specified peer
removeProps(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
removeQueue(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Remove a replication queue.
removeQueue(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
removeQueues(Map<String, List<String>>) - Method in class org.apache.hadoop.hbase.master.cleaner.ReplicationZKNodeCleaner
Remove the undeleted replication queue's zk node for removed peers.
removeQuotesFromByteArray(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Takes a quoted byte array and converts it into an unquoted byte array For example: given a byte array representing 'abc', it returns a byte array representing abc
removeRecoveringRegions(Set<String>, Boolean) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
It removes recovering regions from Coordination
removeRecoveringRegions(Set<String>, Boolean) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
It removes recovering regions under /hbase/recovering-regions/[encoded region name] so that the region server hosting the region can allow reads to the recovered region
removeRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.ServerManager
Called by delete table and similar to notify the ServerManager that a region was removed.
removeRegionFromNamespaceUsage(HRegionInfo) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
 
removeRegionReplicasFromMeta(Set<byte[]>, int, int, Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes some replica columns corresponding to replicas for the passed rows
removeRegions(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.ServerManager
Called by delete table and similar to notify the ServerManager that a region was removed.
removeRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
removeRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
removeRegistry(MetricRegistry) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
removeReplicatorIfQueueIsEmpty(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Remove the znode of region server if the queue is empty.
removeReplicatorIfQueueIsEmpty(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
removeResult(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Mark the specified completed procedure, as ready to remove.
removeRows(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
removeRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Removes RegionServer group associated with the given name.
removeRSGroup(RpcController, RSGroupAdminProtos.RemoveRSGroupRequest, RpcCallback<RSGroupAdminProtos.RemoveRSGroupResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
removeRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
removeRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Remove a region server group.
removeRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
Delete a region server group.
removeScanner(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Removes the scanner associated with the specified ID from the internal id->scanner hash-map.
removeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
Removes the scanner associated with the specified ID from the internal HashMap.
removeServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Remove a server from this group.
removeServerFromDrainList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
removeServers(Set<Address>) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Remove decommissioned servers from rsgroup.
removeServers(RpcController, RSGroupAdminProtos.RemoveServersRequest, RpcCallback<RSGroupAdminProtos.RemoveServersResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
removeServers(Set<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
removeServers(Set<Address>) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Remove decommissioned servers from rsgroup
removeServers(Set<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
removeShutdownHook(Runnable) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
 
removeSourceName(String) - Method in class org.apache.hadoop.metrics2.lib.DefaultMetricsSystemHelper
Unfortunately Hadoop tries to be too-clever and permanently keeps track of all names registered so far as a Source, thus preventing further re-registration of the source with the same name.
removeStackIndex() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
removeStaleRecoveringRegions(Set<String>) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Removes known stale servers
removeStaleRecoveringRegions(Set<String>) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
removeStoreFile(String, Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Archives the specified store file from the specified family.
removeStoreFiles(String, Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Closes and archives the specified store files from the specified family.
removeTable(String) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
 
removeTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
removeTable(TableName) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
removeTableFromNamespaceQuota(TableName) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
Remove table from namespace quota.
removeValue(K, V) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
removeValues(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
removeWALRootPath(Path, Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Checks for the presence of the WAL log root path (using the provided conf object) in the given path.
renameAndSetModifyTime(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
render(Writer) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
render(Writer, AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
 
render(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
 
render(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
render(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
 
render(Writer, CacheConfig, Configuration) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
 
render(Writer, CacheConfig, Configuration, String, String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
 
render(Writer, HRegionServer, List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
 
render(Writer, HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
render(Writer, MetricsRegionServerWrapper, MetricsHBaseServerWrapper) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
 
renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.Intf
 
renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmplImpl
 
renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.Intf
 
renderNoFlush(Writer, AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
 
renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmplImpl
 
renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl.Intf
 
renderNoFlush(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
 
renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmplImpl
 
renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.Intf
 
renderNoFlush(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmplImpl
 
renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.Intf
 
renderNoFlush(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
 
renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmplImpl
 
renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.Intf
 
renderNoFlush(Writer, CacheConfig, Configuration) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
 
renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmplImpl
 
renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.Intf
 
renderNoFlush(Writer, CacheConfig, Configuration, String, String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
 
renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmplImpl
 
renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.Intf
 
renderNoFlush(Writer, HRegionServer, List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
 
renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmplImpl
 
renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.Intf
 
renderNoFlush(Writer, HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmplImpl
 
renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.Intf
 
renderNoFlush(Writer, MetricsRegionServerWrapper, MetricsHBaseServerWrapper) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
 
renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmplImpl
 
renew - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
renewLease() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
renewLease() - Method in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
 
renewLease() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
Allow the client to renew the scanner's lease on the server.
renewLease() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
 
renewLease(String) - Method in class org.apache.hadoop.hbase.regionserver.Leases
Renew a lease
reOpenAllRegions(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
reOpenAllRegions(MasterProcedureEnv, TableName, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterDDLOperationHelper
Reopen all regions from a table after a schema change operation.
repeat(char, int) - Static method in class org.apache.hadoop.hbase.util.Strings
 
replace(K, V, V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
replace(K, V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
replaceValue(V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Replace the value of this entry.
replay(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Replay the given changes when distributedLogReplay WAL edits from a failed RS.
REPLAY_BATCH_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySource
 
REPLAY_BATCH_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySource
 
REPLAY_DATA_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySource
 
REPLAY_DATA_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySource
 
REPLAY_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
REPLAY_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLAY_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySource
 
REPLAY_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySource
 
replayCompactionMarker(WALProtos.CompactionDescriptor, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Call to complete a compaction.
replayCompactionMarker(WALProtos.CompactionDescriptor, boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Call to complete a compaction.
replayEntries(List<Pair<HRegionLocation, WAL.Entry>>) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEditsReplaySink
Replay an array of actions of the same region directly into the newly assigned Region Server
ReplayHLogKey - Class in org.apache.hadoop.hbase.regionserver.wal
An HLogKey specific to WalEdits coming from replay.
ReplayHLogKey(byte[], TableName, long, List<UUID>, long, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ReplayHLogKey
 
ReplayHLogKey(byte[], TableName, long, long, List<UUID>, long, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ReplayHLogKey
 
replayRecoveredEditsIfAny(Map<byte[], Long>, CancelableProgressable, MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Read the edits put under this region by wal splitting process.
REPLICA_ID - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
REPLICA_ID_DELIMITER - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
REPLICA_ID_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
REPLICA_ID_FORMAT - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
replicaId - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
replicaId - Variable in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
replicaRegionsNotRecordedInMeta(Set<HRegionInfo>, MasterServices) - Static method in class org.apache.hadoop.hbase.master.AssignmentManager
Get a list of replica regions that are: not recorded in meta yet.
replicate(ReplicationEndpoint.ReplicateContext) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
Do the shipping logic
replicate() - Method in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
 
replicate(ReplicationEndpoint.ReplicateContext) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
 
replicate(ReplicationEndpoint.ReplicateContext) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Replicate the given set of entries (in the context) to the other cluster.
replicate(ReplicationEndpoint.ReplicateContext) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
replicateEntries(AdminProtos.AdminService.BlockingInterface, List<WAL.Entry>, String, Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint.Replicator
 
replicateEntries(List<AdminProtos.WALEntry>, CellScanner, String, String, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
Replicate this array of entries directly into the local cluster using the native client.
replicateLogEntries(List<AdminProtos.WALEntry>, CellScanner, String, String, String) - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSinkService
Carry on the list of log entries down to the sink
replicateLogEntries(List<AdminProtos.WALEntry>, CellScanner, String, String, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
Carry on the list of log entries down to the sink
replicateWALEntry(AdminProtos.AdminService.BlockingInterface, WAL.Entry[], String, Path, Path) - Static method in class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
A helper to replicate a list of WAL entries using admin protocol.
replicateWALEntry(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Replicate WAL entries on the region server.
REPLICATION - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
 
Replication - Class in org.apache.hadoop.hbase.replication.regionserver
Gateway to Replication.
Replication(Server, FileSystem, Path, Path) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.Replication
Instantiate the replication management (if rep is enabled).
Replication() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.Replication
Empty constructor
REPLICATION_BULKLOAD_COPY_HFILES_PERTHREAD_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
 
REPLICATION_BULKLOAD_COPY_HFILES_PERTHREAD_KEY - Static variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
Number of hfiles to copy per thread during replication
REPLICATION_BULKLOAD_COPY_MAXTHREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
 
REPLICATION_BULKLOAD_COPY_MAXTHREADS_KEY - Static variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
Maximum number of threads to allow in pool to copy hfiles during replication
REPLICATION_BULKLOAD_ENABLE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_BULKLOAD_ENABLE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_CLUSTER_ID - Static variable in class org.apache.hadoop.hbase.HConstants
Replication cluster id of source cluster which uniquely identifies itself with peer cluster
REPLICATION_CODEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for setting replication codec class name
REPLICATION_CONF_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
Directory where the source cluster file system client configuration are placed which is used by sink cluster to copy HFiles from source cluster file system
REPLICATION_DROP_ON_DELETED_TABLE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Drop edits for tables that been deleted from the replication source and target
REPLICATION_ENABLE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_ENABLE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
REPLICATION_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
REPLICATION_SCOPE_BYTES - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
REPLICATION_SCOPE_GLOBAL - Static variable in class org.apache.hadoop.hbase.HConstants
Scope tag for globally scoped data.
REPLICATION_SCOPE_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
Scope tag for locally scoped data.
REPLICATION_SERVICE_CLASSNAME_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_SINK_SERVICE_CLASSNAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_SOURCE_MAXTHREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum number of threads used by the replication source for shipping edits to the sinks
REPLICATION_SOURCE_MAXTHREADS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum number of threads used by the replication source for shipping edits to the sinks
REPLICATION_SOURCE_SERVICE_CLASSNAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_WALENTRYFILTER_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
ReplicationAdmin - Class in org.apache.hadoop.hbase.client.replication
This class provides the administrative interface to HBase cluster replication.
ReplicationAdmin(Configuration) - Constructor for class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Constructor that creates a connection to the local ZooKeeper ensemble.
ReplicationChecker - Class in org.apache.hadoop.hbase.util.hbck
 
ReplicationChecker(Configuration, ZooKeeperWatcher, HConnection, HBaseFsck.ErrorReporter) - Constructor for class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
 
ReplicationEndpoint - Interface in org.apache.hadoop.hbase.replication
ReplicationEndpoint is a plugin which implements replication to other HBase clusters, or other systems.
ReplicationEndpoint.Context - Class in org.apache.hadoop.hbase.replication
 
ReplicationEndpoint.Context(Configuration, Configuration, FileSystem, String, UUID, ReplicationPeer, MetricsSource, TableDescriptors, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
ReplicationEndpoint.ReplicateContext - Class in org.apache.hadoop.hbase.replication
ReplicationEndpoint.ReplicateContext() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
 
ReplicationException - Exception in org.apache.hadoop.hbase.replication
An HBase Replication exception.
ReplicationException() - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
 
ReplicationException(String) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
 
ReplicationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
 
ReplicationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
 
ReplicationFactory - Class in org.apache.hadoop.hbase.replication
A factory class for instantiating replication objects that deal with replication state.
ReplicationFactory() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationFactory
 
REPLICATIONGLOBAL - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
ReplicationHFileCleaner - Class in org.apache.hadoop.hbase.replication.master
Implementation of a file cleaner that checks if a hfile is still scheduled for replication before deleting it from hfile archive directory.
ReplicationHFileCleaner() - Constructor for class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
 
ReplicationListener - Interface in org.apache.hadoop.hbase.replication
The replication listener interface can be implemented if a class needs to subscribe to events generated by the ReplicationTracker.
ReplicationLoad - Class in org.apache.hadoop.hbase.replication.regionserver
This class is used for exporting some of the info from replication metrics
ReplicationLoad() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
default constructor
ReplicationLoadSink - Class in org.apache.hadoop.hbase.replication
A HBase ReplicationLoad to present MetricsSink information
ReplicationLoadSink(long, long) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
ReplicationLoadSource - Class in org.apache.hadoop.hbase.replication
A HBase ReplicationLoad to present MetricsSource information
ReplicationLoadSource(String, long, int, long, long) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
ReplicationLogCleaner - Class in org.apache.hadoop.hbase.replication.master
Implementation of a log cleaner that checks if a log is still scheduled for replication before deleting it when its TTL is over.
ReplicationLogCleaner() - Constructor for class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
 
ReplicationLogCleaner.WarnOnlyAbortable - Class in org.apache.hadoop.hbase.replication.master
 
ReplicationLogCleaner.WarnOnlyAbortable() - Constructor for class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner.WarnOnlyAbortable
 
ReplicationObserver - Class in org.apache.hadoop.hbase.replication.regionserver
An Observer to facilitate replication operations
ReplicationObserver() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationObserver
 
ReplicationPeer - Interface in org.apache.hadoop.hbase.replication
ReplicationPeer manages enabled / disabled state for the peer.
ReplicationPeer.PeerState - Enum in org.apache.hadoop.hbase.replication
State of the peer, whether it is enabled or not
ReplicationPeerConfig - Class in org.apache.hadoop.hbase.replication
A configuration for the replication peer cluster.
ReplicationPeerConfig() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
ReplicationPeerConfigListener - Interface in org.apache.hadoop.hbase.replication
 
ReplicationPeers - Interface in org.apache.hadoop.hbase.replication
This provides an interface for maintaining a set of peer clusters.
ReplicationPeersZKImpl - Class in org.apache.hadoop.hbase.replication
This class provides an implementation of the ReplicationPeers interface using Zookeeper.
ReplicationPeersZKImpl(ZooKeeperWatcher, Configuration, ReplicationQueuesClient, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
ReplicationPeerZKImpl - Class in org.apache.hadoop.hbase.replication
 
ReplicationPeerZKImpl(ZooKeeperWatcher, Configuration, String, ReplicationPeerConfig, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
Constructor that takes all the objects required to communicate with the specified peer, except for the region server addresses.
ReplicationPeerZKImpl.PeerConfigTracker - Class in org.apache.hadoop.hbase.replication
Tracker for PeerConfigNode of this peer
ReplicationPeerZKImpl.PeerConfigTracker(String, ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerConfigTracker
 
ReplicationPeerZKImpl.PeerStateTracker - Class in org.apache.hadoop.hbase.replication
Tracker for state of this peer
ReplicationPeerZKImpl.PeerStateTracker(String, ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl.PeerStateTracker
 
ReplicationProtbufUtil - Class in org.apache.hadoop.hbase.protobuf
 
ReplicationProtbufUtil() - Constructor for class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
 
ReplicationQueueInfo - Class in org.apache.hadoop.hbase.replication
This class is responsible for the parsing logic for a znode representing a queue.
ReplicationQueueInfo(String) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
The passed znode will be either the id of the peer cluster or the handling story of that queue in the form of id-servername-*
ReplicationQueues - Interface in org.apache.hadoop.hbase.replication
This provides an interface for maintaining a region server's replication queues.
ReplicationQueuesClient - Interface in org.apache.hadoop.hbase.replication
This provides an interface for clients of replication to view replication queues.
ReplicationQueuesClientZKImpl - Class in org.apache.hadoop.hbase.replication
 
ReplicationQueuesClientZKImpl(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
 
ReplicationQueuesZKImpl - Class in org.apache.hadoop.hbase.replication
This class provides an implementation of the ReplicationQueues interface using Zookeeper.
ReplicationQueuesZKImpl(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
ReplicationSerDeHelper - Class in org.apache.hadoop.hbase.replication
 
ReplicationService - Interface in org.apache.hadoop.hbase.regionserver
Gateway to Cluster Replication.
ReplicationSink - Class in org.apache.hadoop.hbase.replication.regionserver
This class is responsible for replicating the edits coming from another cluster.
ReplicationSink(Configuration, Stoppable) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
Create a sink for replication
replicationSinkHandler - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
ReplicationSinkManager - Class in org.apache.hadoop.hbase.replication.regionserver
Maintains a collection of peers to replicate to, and randomly selects a single peer to replicate to per set of data to replicate.
ReplicationSinkManager(HConnection, String, HBaseReplicationEndpoint, Configuration) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
Instantiate for a single replication peer cluster.
ReplicationSinkManager.SinkPeer - Class in org.apache.hadoop.hbase.replication.regionserver
Wraps a replication region server sink to provide the ability to identify it.
ReplicationSinkManager.SinkPeer(ServerName, AdminProtos.AdminService.BlockingInterface) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager.SinkPeer
 
ReplicationSinkService - Interface in org.apache.hadoop.hbase.regionserver
A sink for a replication stream has to expose this service.
ReplicationSource - Class in org.apache.hadoop.hbase.replication.regionserver
Class that handles the source of a replication stream.
ReplicationSource() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
ReplicationSource.LogsComparator - Class in org.apache.hadoop.hbase.replication.regionserver
Comparator used to compare logs together based on their start time
ReplicationSource.LogsComparator() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.LogsComparator
 
ReplicationSource.ReplicationSourceShipperThread - Class in org.apache.hadoop.hbase.replication.regionserver
 
ReplicationSource.ReplicationSourceShipperThread(String, PriorityBlockingQueue<Path>, ReplicationQueueInfo, ReplicationSourceInterface) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.ReplicationSourceShipperThread
 
ReplicationSource.WorkerState - Enum in org.apache.hadoop.hbase.replication.regionserver
 
replicationSourceHandler - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
ReplicationSourceInterface - Interface in org.apache.hadoop.hbase.replication.regionserver
Interface that defines a replication source
ReplicationSourceManager - Class in org.apache.hadoop.hbase.replication.regionserver
This class is responsible to manage all the replication sources.
ReplicationSourceManager(ReplicationQueues, ReplicationPeers, ReplicationTracker, Configuration, Server, FileSystem, Path, Path, UUID) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Creates a replication manager and sets the watch on all the other registered region servers
ReplicationSourceService - Interface in org.apache.hadoop.hbase.regionserver
A source for a replication stream has to expose this service.
ReplicationSourceWALReaderThread - Class in org.apache.hadoop.hbase.replication.regionserver
Reads and filters WAL entries, groups the filtered entries into batches, and puts the batches onto a queue
ReplicationSourceWALReaderThread(ReplicationSourceManager, ReplicationQueueInfo, PriorityBlockingQueue<Path>, long, FileSystem, Configuration, WALEntryFilter, MetricsSource) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReaderThread
Creates a reader worker for a given WAL queue.
ReplicationStateZKBase - Class in org.apache.hadoop.hbase.replication
This is a base class for maintaining replication state in zookeeper.
ReplicationStateZKBase(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
ReplicationSyncUp - Class in org.apache.hadoop.hbase.replication.regionserver
In a scenario of Replication based Disaster/Recovery, when hbase Master-Cluster crashes, this tool is used to sync-up the delta from Master to Slave using the info from Zookeeper.
ReplicationSyncUp() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
 
ReplicationThrottler - Class in org.apache.hadoop.hbase.replication.regionserver
Per-peer per-node throttling controller for replication: enabled if bandwidth > 0, a cycle = 100ms, by throttling we guarantee data pushed to peer within each cycle won't exceed 'bandwidth' bytes
ReplicationThrottler(double) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
ReplicationThrottler constructor If bandwidth less than 1, throttling is disabled
ReplicationTracker - Interface in org.apache.hadoop.hbase.replication
This is the interface for a Replication Tracker.
ReplicationTrackerZKImpl - Class in org.apache.hadoop.hbase.replication
This class is a Zookeeper implementation of the ReplicationTracker interface.
ReplicationTrackerZKImpl(ZooKeeperWatcher, ReplicationPeers, Configuration, Abortable, Stoppable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
 
ReplicationTrackerZKImpl.OtherRegionServerWatcher - Class in org.apache.hadoop.hbase.replication
Watcher used to be notified of the other region server's death in the local cluster.
ReplicationTrackerZKImpl.OtherRegionServerWatcher(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.OtherRegionServerWatcher
Construct a ZooKeeper event listener.
ReplicationTrackerZKImpl.PeersWatcher - Class in org.apache.hadoop.hbase.replication
Watcher used to follow the creation and deletion of peer clusters.
ReplicationTrackerZKImpl.PeersWatcher(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl.PeersWatcher
Construct a ZooKeeper event listener.
REPLICATIONTYPE - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
ReplicationZKLockCleanerChore - Class in org.apache.hadoop.hbase.master.cleaner
A cleaner that cleans replication locks on zk which is locked by dead region servers
ReplicationZKLockCleanerChore(Stoppable, Abortable, int, ZooKeeperWatcher, Configuration) - Constructor for class org.apache.hadoop.hbase.master.cleaner.ReplicationZKLockCleanerChore
 
ReplicationZKNodeCleaner - Class in org.apache.hadoop.hbase.master.cleaner
Used to clean the replication queues belonging to the peer which does not exist.
ReplicationZKNodeCleaner(Configuration, ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.master.cleaner.ReplicationZKNodeCleaner
 
ReplicationZKNodeCleanerChore - Class in org.apache.hadoop.hbase.master.cleaner
Chore that will clean the replication queues belonging to the peer which does not exist.
ReplicationZKNodeCleanerChore(Stoppable, int, ReplicationZKNodeCleaner) - Constructor for class org.apache.hadoop.hbase.master.cleaner.ReplicationZKNodeCleanerChore
 
replicationZNode - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the base znode that contains all replication state.
report(String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
report(HBaseFsck.ErrorReporter) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
Print a human readable summary of hfile quarantining operations.
reportBadSink(ReplicationSinkManager.SinkPeer) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
Report a SinkPeer as being bad (i.e.
reportCompactionRequestEnd(boolean, int, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
reportCompactionRequestFailure() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
reportCompactionRequestStart(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
reporter - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
reportError(String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
reportError(HBaseFsck.ErrorReporter.ERROR_CODE, String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
reportError(HBaseFsck.ErrorReporter.ERROR_CODE, String, HBaseFsck.TableInfo) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
reportError(HBaseFsck.ErrorReporter.ERROR_CODE, String, HBaseFsck.TableInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
reportError(HBaseFsck.ErrorReporter.ERROR_CODE, String, HBaseFsck.TableInfo, HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
reportOperationFromWal(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
Reports the operation from WAL during replay.
reportRegionStateTransition(RpcController, RegionServerStatusProtos.ReportRegionStateTransitionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
reportRegionStateTransition(RegionServerStatusProtos.RegionStateTransition.TransitionCode, HRegionInfo...) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
reportRegionStateTransition(RegionServerStatusProtos.RegionStateTransition.TransitionCode, long, HRegionInfo...) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
reportRegionStateTransition(RegionServerServices.RegionStateTransitionContext) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
reportRegionStateTransition(RegionServerServices.RegionStateTransitionContext) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
Notify master that a handler requests to change a region state
reportRegionStateTransition(RegionServerStatusProtos.RegionStateTransition.TransitionCode, long, HRegionInfo...) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
reportRegionStateTransition(RegionServerStatusProtos.RegionStateTransition.TransitionCode, HRegionInfo...) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
reportRSFatalError(RpcController, RegionServerStatusProtos.ReportRSFatalErrorRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
reportSinkSuccess(ReplicationSinkManager.SinkPeer) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
Report that a SinkPeer successfully replicated a chunk of data.
request(Path, Runnable) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
 
request - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
 
request - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
 
REQUEST_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
REQUEST_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
REQUEST_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
requestCompaction(Region, String) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
 
requestCompaction(Region, String, List<Pair<CompactionRequest, Store>>) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
 
requestCompaction(Region, Store, String, CompactionRequest) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
 
requestCompaction(Region, String, int, List<Pair<CompactionRequest, Store>>, User) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
 
requestCompaction(Region, Store, String, int, CompactionRequest, User) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
 
requestCompaction(Region, String) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestCompaction(Region, String, List<Pair<CompactionRequest, Store>>) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestCompaction(Region, Store, String, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestCompaction(Region, String, int, List<Pair<CompactionRequest, Store>>, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestCompaction(Region, Store, String, int, CompactionRequest, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
requestCompaction(int, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
requestCompaction(int, CompactionRequest, User) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
requestCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
requestCompaction(int, CompactionRequest) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Deprecated.
see requestCompaction(int, CompactionRequest, User)
requestCompaction(int, CompactionRequest, User) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
RequestConverter - Class in org.apache.hadoop.hbase.protobuf
Helper utility to build protocol buffer requests, or build components for protocol buffer requests.
RequestCountPerSecond - Class in org.apache.hadoop.hbase.hbtop.mode
Utility class for calculating request counts per second.
RequestCountPerSecond() - Constructor for class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
 
requestDelayedFlush(Region, long, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
Tell the listener the cache needs to be flushed after a delay
requestedSize() - Method in exception org.apache.hadoop.hbase.io.hfile.bucket.CacheFullException
 
requestFlush(Region, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
Tell the listener the cache needs to be flushed.
requestLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
requestRegionsMerge(Region, Region, boolean, long, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestRollAll() - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
 
REQUESTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
REQUESTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
requestSeek(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Similar to KeyValueScanner.seek(org.apache.hadoop.hbase.Cell) (or KeyValueScanner.reseek(org.apache.hadoop.hbase.Cell) if forward is true) but only does a seek operation after checking that it is really necessary for the row/column combination specified by the kv parameter.
requestSeek(Cell, boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Similar to KeyValueScanner.seek(org.apache.hadoop.hbase.Cell) (or KeyValueScanner.reseek(org.apache.hadoop.hbase.Cell) if forward is true) but only does a seek operation after checking that it is really necessary for the row/column combination specified by the kv parameter.
requestSeek(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
 
requestSeek(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
 
requestSeek(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
Pretend we have done a seek but don't do it yet, if possible.
requestSplit(Region) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestSplit(Region, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestSplit(Region, byte[], User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestSystemCompaction(Region, String) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestSystemCompaction(Region, Store, String) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
RequestTooBigException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when the size of the rpc request received by the server is too large.
RequestTooBigException() - Constructor for exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
 
RequestTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
 
requireAccess(User, String, TableName, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
Authorizes that the current user has any of the given permissions to access the table.
requireAccess(String, TableName, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
Authorizes that the current user has any of the given permissions to access the table.
requireExclusiveLock(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler.ServerQueue
 
requireExclusiveLock(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler.TableQueue
 
requireGlobalPermission(User, String, Permission.Action, TableName, Map<byte[], ? extends Collection<byte[]>>) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
Checks that the user has the given global permission.
requireGlobalPermission(User, String, Permission.Action, String) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
Checks that the user has the given global permission.
requireGlobalPermission(String, Permission.Action, TableName, Map<byte[], ? extends Collection<byte[]>>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
Checks that the user has the given global permission.
requireGlobalPermission(String, Permission.Action, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
Checks that the user has the given global permission.
requireNamespacePermission(User, String, String, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
Checks that the user has the given global or namespace permission.
requireNamespacePermission(User, String, String, TableName, Map<byte[], ? extends Collection<byte[]>>, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
Checks that the user has the given global or namespace permission.
requireNamespacePermission(String, String, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
Checks that the user has the given global or namespace permission.
requireNamespacePermission(String, String, TableName, Map<byte[], ? extends Collection<byte[]>>, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
Checks that the user has the given global or namespace permission.
requirePermission(User, String, TableName, byte[], byte[], Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
Authorizes that the current user has any of the given permissions for the given table, column family and column qualifier.
requirePermission(User, String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
Authorizes that the current user has global privileges for the given action.
requirePermission(String, TableName, byte[], byte[], Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
Authorizes that the current user has any of the given permissions for the given table, column family and column qualifier.
requirePermission(String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AccessController
Authorizes that the current user has global privileges for the given action.
requiresLayout() - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
 
requireTablePermission(User, String, TableName, byte[], byte[], Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
Authorizes that the current user has any of the given permissions for the given table, column family and column qualifier.
requireTablePermission(String, TableName, byte[], byte[], Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
Authorizes that the current user has any of the given permissions for the given table, column family and column qualifier.
reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
Move forward on the sub-lists set previously by seek.
reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
This function is identical to the KeyValueHeap.seek(Cell) function except that scanner.seek(seekKey) is changed to scanner.reseek(seekKey).
reseek(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Reseek the scanner at or after the specified KeyValue.
reseek(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
Do a reseek to the required row.
reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
 
reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
reseek(Cell) - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
reseekTo(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
reseekTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
reseekTo(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
reseekTo(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Deprecated.
reseekTo(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Deprecated.
reseekTo(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
RESERVED_NAMESPACES - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
RESERVED_NAMESPACES_BYTES - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
reset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
 
reset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
construct
reset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
reset(OutputStream, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
reset(TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
reset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
reset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
reset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
reset() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.Filter
Reset the state of the filter between rows.
reset() - Method in class org.apache.hadoop.hbase.filter.FilterBase
Filters that are purely stateless and do nothing in their reset() methods can inherit this null/empty implementation.
reset() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
reset() - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
reset() - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
reset() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
reset() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
reset() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
reset() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
reset() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
reset() - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
Resets the pos field of this byte array output stream to zero.
reset() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
 
reset() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
 
reset() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
Reset state, reinitialize with the key and iv
reset() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Reset state, reinitialize with the key and iv
reset() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
 
reset() - Method in class org.apache.hadoop.hbase.io.LimitInputStream
 
reset() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
reset() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
reset() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
reset() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureIterator
Reset the Iterator by seeking to the beginning of the list.
reset() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
reset() - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
 
reset() - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
Called between rows.
reset() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
Resets the Matcher
reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.LegacyScanQueryMatcher
Deprecated.
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
reset() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
Should be called if the stream is to be reused (i.e.
reset() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
reset() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
 
reset() - Method in class org.apache.hadoop.hbase.types.StructBuilder
Reset the sequence of accumulated fields.
reset() - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
reset() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
Resets the managed instance to the default instance: DefaultEnvironmentEdge.
reset() - Method in class org.apache.hadoop.hbase.util.FastLongHistogram
Deprecated.
Resets the histogram for new counting.
reset() - Method in class org.apache.hadoop.hbase.util.LongAdder
Resets variables maintaining the sum to zero.
reset() - Method in interface org.apache.hadoop.hbase.wal.WAL.Reader
 
resetBuf(int) - Method in class org.apache.hadoop.hbase.codec.BaseDecoder.PBIS
 
resetBuffer() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
 
resetBuffer() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
resetCacheConfig(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Enable a basic on-heap cache for these jobs.
resetCounters() - Static method in class org.apache.hadoop.hbase.SplitLogCounters
 
resetErrors() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
resetFanIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
resetKVHeap(List<? extends KeyValueScanner>, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
resetMembers(Procedure) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
Notify Members to reset the distributed state for procedure
resetMembers(Procedure) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
Delete znodes that are no longer in use.
resetScannerStack(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
resetStartTick() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
Reset the cycle start tick to NOW
resetState() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
 
resetToBeforeFirstEntry() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
resetToBeforeFirstEntry() - Method in interface org.apache.hadoop.hbase.codec.prefixtree.scanner.CellSearcher
Reset any state in the scanner so it appears it was freshly opened.
resetUpdates() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
resetUpdates() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
ResizableBlockCache - Interface in org.apache.hadoop.hbase.io.hfile
BlockCache which is resizable.
resizeQueues(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
Update current soft limit for executor's call queues
ResourceBase - Class in org.apache.hadoop.hbase.rest
 
ResourceBase() - Constructor for class org.apache.hadoop.hbase.rest.ResourceBase
 
ResourceConfig - Class in org.apache.hadoop.hbase.rest
 
ResourceConfig() - Constructor for class org.apache.hadoop.hbase.rest.ResourceConfig
 
responder - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
responder - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
response - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
Chain of buffers to send as response.
Response - Class in org.apache.hadoop.hbase.rest.client
The HTTP result code, response headers, and body of a HTTP response.
Response(int) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
Constructor
Response(int, Header[]) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
Constructor
Response(int, Header[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
Constructor
Response(int, Header[], byte[], InputStream) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
Constructor
RESPONSE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
RESPONSE_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
ResponseConverter - Class in org.apache.hadoop.hbase.protobuf
Helper utility to build protocol buffer responses, or retrieve data from protocol buffer responses.
responseQueue - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
REST_AUTHENTICATION_PRINCIPAL - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_AUTHENTICATION_TYPE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_DNS_INTERFACE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_DNS_NAMESERVER - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
rest_jsp - Class in org.apache.hadoop.hbase.generated.rest
 
rest_jsp() - Constructor for class org.apache.hadoop.hbase.generated.rest.rest_jsp
 
REST_KERBEROS_PRINCIPAL - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_KEYTAB_FILE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_ENABLED - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_KEYSTORE_KEYPASSWORD - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_KEYSTORE_PASSWORD - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
REST_SSL_KEYSTORE_STORE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
Restart from survivable exceptions by creating a new scanner.
restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
Restart from survivable exceptions by creating a new scanner.
restart(byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Restart from survivable exceptions by creating a new scanner.
restart(byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Restart from survivable exceptions by creating a new scanner.
restart() - Static method in class org.apache.hadoop.metrics2.impl.JmxCacheBuster
Restarts the stopped service.
RestCsrfPreventionFilter - Class in org.apache.hadoop.hbase.rest.filter
This filter provides protection against cross site request forgery (CSRF) attacks for REST APIs.
RestCsrfPreventionFilter() - Constructor for class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
 
RestCsrfPreventionFilter.HttpInteraction - Interface in org.apache.hadoop.hbase.rest.filter
Defines the minimal API requirements for the filter to execute its filtering logic.
RESTDemoClient - Class in org.apache.hadoop.hbase.rest
 
RESTDemoClient() - Constructor for class org.apache.hadoop.hbase.rest.RESTDemoClient
 
RESTORE_DIR_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
 
RESTORE_DIRS_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
 
restoreEdit(Store, Cell) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Used by tests
restoreHdfsRegions() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
Restore the on-disk table to a specified snapshot state.
restoreSnapshot(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(String, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(String, boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Restore the specified snapshot on the original table.
restoreSnapshot(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Restore the specified snapshot on the original table.
restoreSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Restore the specified snapshot on the original table.
restoreSnapshot(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Restore the specified snapshot on the original table.
restoreSnapshot(String, boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Restore the specified snapshot on the original table.
restoreSnapshot(String, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
restoreSnapshot(RpcController, MasterProtos.RestoreSnapshotRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Execute Restore/Clone snapshot operation.
restoreSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Deprecated.
restoreSnapshot(HBaseProtos.SnapshotDescription, boolean) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Restore the specified snapshot
restoreSnapshotACL(HBaseProtos.SnapshotDescription, TableName, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
 
RestoreSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when a snapshot could not be restored due to a server-side error when restoring it.
RestoreSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
Deprecated.
since 1.3.0, will be removed in 3.0.0
RestoreSnapshotException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
Deprecated.
since 1.3.0, will be removed in 3.0.0
RestoreSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
 
RestoreSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
 
RestoreSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
Handler to Restore a snapshot.
RestoreSnapshotHandler(MasterServices, HBaseProtos.SnapshotDescription, HTableDescriptor, boolean) - Constructor for class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
 
RestoreSnapshotHelper - Class in org.apache.hadoop.hbase.snapshot
Helper to Restore/Clone a Snapshot
RestoreSnapshotHelper(Configuration, FileSystem, SnapshotManifest, HTableDescriptor, Path, ForeignExceptionDispatcher, MonitoredTask) - Constructor for class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
 
RestoreSnapshotHelper(Configuration, FileSystem, SnapshotManifest, HTableDescriptor, Path, ForeignExceptionDispatcher, MonitoredTask, boolean) - Constructor for class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
 
RestoreSnapshotHelper.RestoreMetaChanges - Class in org.apache.hadoop.hbase.snapshot
Describe the set of operations needed to update hbase:meta after restore.
restoreSnapshots(Configuration, Map<String, Path>, FileSystem) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
Restore each (snapshot name, restore directory) pair in snapshotToDir
RESTServer - Class in org.apache.hadoop.hbase.rest
Main class for launching REST gateway as a servlet hosted by Jetty.
RESTServer() - Constructor for class org.apache.hadoop.hbase.rest.RESTServer
 
RESTServlet - Class in org.apache.hadoop.hbase.rest
Singleton class encapsulating global REST servlet state and functions.
RESTServletContainer - Class in org.apache.hadoop.hbase.rest
REST servlet container.
RESTServletContainer() - Constructor for class org.apache.hadoop.hbase.rest.RESTServletContainer
 
RESTVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
resubmitTask(String, SplitLogManager.Task, SplitLogManager.ResubmitDirective) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Resubmit the task in case if found unassigned or failed
resubmitTask(String, SplitLogManager.Task, SplitLogManager.ResubmitDirective) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
resubmitThresholdReached - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
Result - Class in org.apache.hadoop.hbase.client
Single row result of a Get or Scan query.
Result() - Constructor for class org.apache.hadoop.hbase.client.Result
Creates an empty Result w/ no KeyValue payload; returns null if you call Result.rawCells().
Result(KeyValue[]) - Constructor for class org.apache.hadoop.hbase.client.Result
Deprecated.
Use Result.create(List) instead.
Result(List<KeyValue>) - Constructor for class org.apache.hadoop.hbase.client.Result
Deprecated.
Use Result.create(List) instead.
ResultBoundedCompletionService<V> - Class in org.apache.hadoop.hbase.client
A completion service for the RpcRetryingCallerFactory.
ResultBoundedCompletionService(RpcRetryingCallerFactory, Executor, int) - Constructor for class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
resultFromHBase(Result) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
Creates a TResult (Thrift) from a Result (HBase).
ResultGenerator - Class in org.apache.hadoop.hbase.rest
 
ResultGenerator() - Constructor for class org.apache.hadoop.hbase.rest.ResultGenerator
 
ResultScanner - Interface in org.apache.hadoop.hbase.client
Interface for client-side scanning.
ResultSerialization - Class in org.apache.hadoop.hbase.mapreduce
 
ResultSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
resultsFromHBase(Result[]) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
Converts multiple Results (HBase) into a list of TResults (Thrift).
ResultStatsUtil - Class in org.apache.hadoop.hbase.client
A Result with some statistics about the server/region status
resume(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedList
 
retainAssignment(Map<HRegionInfo, ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Generates a bulk assignment startup plan, attempting to reuse the existing assignment information from META, but adjusting for the specified list of available/online servers available for assignment.
retainAssignment(Map<HRegionInfo, ServerName>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Assign regions to the previously hosting region server
retainAssignment(Map<HRegionInfo, ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
rethrowException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
 
rethrowException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
Rethrow an exception currently held by the ForeignExceptionSnare.
rethrowException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
rethrowExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
 
rethrowExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
 
rethrowExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
rethrowExceptionIfFailed() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
Rethrow the exception returned by SnapshotSentinel.getExceptionIfFailed().
rethrowIfInterrupt(Throwable) - Static method in class org.apache.hadoop.hbase.util.ExceptionUtil
 
RETRIES_BY_SERVER_KEY - Static variable in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
RetriesExhaustedException - Exception in org.apache.hadoop.hbase.client
Exception thrown by HTable methods when an attempt to do something (like commit changes) fails after a bunch of retries.
RetriesExhaustedException(String) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
 
RetriesExhaustedException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
 
RetriesExhaustedException(String, int, List<Throwable>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
Create a new RetriesExhaustedException from the list of prior failures.
RetriesExhaustedException(int, List<RetriesExhaustedException.ThrowableWithExtraContext>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
Create a new RetriesExhaustedException from the list of prior failures.
RetriesExhaustedException.ThrowableWithExtraContext - Class in org.apache.hadoop.hbase.client
Datastructure that allows adding more info around Throwable incident.
RetriesExhaustedException.ThrowableWithExtraContext(Throwable, long, String) - Constructor for class org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
 
RetriesExhaustedWithDetailsException - Exception in org.apache.hadoop.hbase.client
This subclass of RetriesExhaustedException is thrown when we have more information about which rows were causing which exceptions on what servers.
RetriesExhaustedWithDetailsException(String) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
RetriesExhaustedWithDetailsException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
RetriesExhaustedWithDetailsException(List<Throwable>, List<Row>, List<String>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
retrieveGetCounterWithStringsParams(TaskAttemptContext) - Static method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
In new mapreduce APIs, TaskAttemptContext has two getCounter methods Check if getCounter(String, String) method is available.
retrieveGroupList(Table) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupSerDe
 
retrieveGroupList(ZooKeeperWatcher, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupSerDe
 
retrievePassword(AuthenticationTokenIdentifier) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
RETRY_BACKOFF - Static variable in class org.apache.hadoop.hbase.HConstants
Retrying we multiply hbase.client.pause setting by what we have in this array until we run out of array items.
RetryCounter - Class in org.apache.hadoop.hbase.util
 
RetryCounter(int, long, TimeUnit) - Constructor for class org.apache.hadoop.hbase.util.RetryCounter
 
RetryCounter(RetryCounter.RetryConfig) - Constructor for class org.apache.hadoop.hbase.util.RetryCounter
 
RetryCounter.BackoffPolicy - Class in org.apache.hadoop.hbase.util
Policy for calculating sleeping intervals between retry attempts
RetryCounter.BackoffPolicy() - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.BackoffPolicy
 
RetryCounter.ExponentialBackoffPolicy - Class in org.apache.hadoop.hbase.util
 
RetryCounter.ExponentialBackoffPolicy() - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicy
 
RetryCounter.ExponentialBackoffPolicyWithLimit - Class in org.apache.hadoop.hbase.util
 
RetryCounter.ExponentialBackoffPolicyWithLimit() - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicyWithLimit
 
RetryCounter.RetryConfig - Class in org.apache.hadoop.hbase.util
Configuration for a retry counter
RetryCounter.RetryConfig() - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
 
RetryCounter.RetryConfig(int, long, long, TimeUnit, RetryCounter.BackoffPolicy) - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
 
RetryCounterFactory - Class in org.apache.hadoop.hbase.util
 
RetryCounterFactory(int, int) - Constructor for class org.apache.hadoop.hbase.util.RetryCounterFactory
 
RetryCounterFactory(int, int, int) - Constructor for class org.apache.hadoop.hbase.util.RetryCounterFactory
 
RetryCounterFactory(RetryCounter.RetryConfig) - Constructor for class org.apache.hadoop.hbase.util.RetryCounterFactory
 
RetryImmediatelyException - Exception in org.apache.hadoop.hbase
 
RetryImmediatelyException(String) - Constructor for exception org.apache.hadoop.hbase.RetryImmediatelyException
 
RetryingCallable<T> - Interface in org.apache.hadoop.hbase.client
A Callable<T> that will be retried.
RETURN_RESULTS - Static variable in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
this field is private as of HBase 2.0.
returnCompressor(Compressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
returnDecompressor(Decompressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
returnToNextScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenPresenter
 
returnToNextScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
returnToNextScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenPresenter
 
ReusableStreamGzipCodec - Class in org.apache.hadoop.hbase.io.compress
Fixes an inefficiency in Hadoop's Gzip codec, allowing to reuse compression streams.
ReusableStreamGzipCodec() - Constructor for class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec
 
ReusableStreamGzipCodec.ReusableGzipOutputStream - Class in org.apache.hadoop.hbase.io.compress
A bridge that wraps around a DeflaterOutputStream to make it a CompressionOutputStream.
ReusableStreamGzipCodec.ReusableGzipOutputStream(OutputStream) - Constructor for class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
 
reversed - Variable in class org.apache.hadoop.hbase.filter.Filter
 
reversed - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
 
reversed - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
ReversedClientScanner - Class in org.apache.hadoop.hbase.client
A reversed client scanner which support backward scanning
ReversedClientScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - Constructor for class org.apache.hadoop.hbase.client.ReversedClientScanner
Create a new ReversibleClientScanner for the specified table Note that the passed Scan's start row maybe changed.
ReversedKeyValueHeap - Class in org.apache.hadoop.hbase.regionserver
ReversedKeyValueHeap is used for supporting reversed scanning.
ReversedKeyValueHeap(List<? extends KeyValueScanner>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
 
reverseDNS(InetAddress) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Deprecated.
mistakenly made public in 0.98.7. scope will change to package-private
ReversedScannerCallable - Class in org.apache.hadoop.hbase.client
A reversed ScannerCallable which supports backward scanning.
ReversedScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.client.ReversedScannerCallable
 
ReversedScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory, int) - Constructor for class org.apache.hadoop.hbase.client.ReversedScannerCallable
 
ReversibleCellScanner - Interface in org.apache.hadoop.hbase.codec.prefixtree.scanner
An extension of CellScanner indicating the scanner supports iterating backwards through cells.
revision - Static variable in class org.apache.hadoop.hbase.Version
 
revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to revoke a user's global permissions.
revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to revoke a user's table permissions.
revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to revoke a user's namespace permissions.
revoke(Connection, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Revokes the permission on the table
revoke(Connection, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Revokes the permission on the table for the specified user.
revoke(Connection, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
Revoke global permissions for the specified user.
revoke(Configuration, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
revoke(Configuration, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
revoke(Configuration, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
revoke(RpcController, AccessControlProtos.RevokeRequest, RpcCallback<AccessControlProtos.RevokeResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
rewind() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
rewind() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
Set position to beginning of given block
rewind() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
rewindThenToList(ByteBuffer, boolean, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
RIT_COUNT_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
RIT_COUNT_OVER_THRESHOLD_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
RIT_DURATION_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
RIT_OLDEST_AGE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
RMI_CONNECTOR_PORT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.JMXListener
 
RMI_REGISTRY_PORT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.JMXListener
 
RNG_ALGORITHM_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
RNG_PROVIDER_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
ROLL_REQUESTED - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
ROLL_REQUESTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
ROLL_RETRIES_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
ROLL_THRESHOLD_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
rollback(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
The code to undo what done by the execute() code.
rollback(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureInMemoryChore
 
rollback(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
 
rollback(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Remove n key from the memstore.
rollback(Cell) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
rollback(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Remove n key from the memstore.
rollback(Server, RegionServerServices) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
Deprecated.
use #rollback(Server, RegionServerServices, User)
rollback(Server, RegionServerServices, User) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
Roll back a failed transaction
rollback(RegionMergeTransaction, RegionMergeTransaction.RegionMergeTransactionPhase, RegionMergeTransaction.RegionMergeTransactionPhase) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.TransactionListener
Invoked when rolling back a transaction from one transaction phase to the previous
rollback(Server, RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
 
rollback(Server, RegionServerServices, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
 
rollback(Server, RegionServerServices) - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
Deprecated.
use #rollback(Server, RegionServerServices, User)
rollback(Server, RegionServerServices, User) - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
Roll back a failed transaction
rollback(SplitTransaction, SplitTransaction.SplitTransactionPhase, SplitTransaction.SplitTransactionPhase) - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction.TransactionListener
Invoked when rolling back a transaction from one transaction phase to the previous
rollback(Server, RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
 
rollback(Server, RegionServerServices, User) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
 
rollback(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Removes a Cell from the memstore.
rollbackRegionReplayEditsSize(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
Roll back the global MemStore size for a specified region when this region can't be opened.
rollbackState(MasterProcedureEnv, MasterProcedureProtos.AddColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
rollbackState(MasterProcedureEnv, MasterProcedureProtos.CreateNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
rollbackState(MasterProcedureEnv, MasterProcedureProtos.CreateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
rollbackState(MasterProcedureEnv, MasterProcedureProtos.DeleteColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
rollbackState(MasterProcedureEnv, MasterProcedureProtos.DeleteNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
rollbackState(MasterProcedureEnv, MasterProcedureProtos.DeleteTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
rollbackState(MasterProcedureEnv, MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
rollbackState(MasterProcedureEnv, MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
rollbackState(MasterProcedureEnv, MasterProcedureProtos.ModifyColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
rollbackState(MasterProcedureEnv, MasterProcedureProtos.ModifyNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
rollbackState(MasterProcedureEnv, MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
rollbackState(MasterProcedureEnv, MasterProcedureProtos.ServerCrashState) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
rollbackState(MasterProcedureEnv, MasterProcedureProtos.TruncateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
rollbackState(TEnvironment, TState) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
called to perform the rollback of the specified state
rollHLogWriter(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
RollingStatCalculator - Class in org.apache.hadoop.hbase.util
This class maintains mean and variation for any sequence of input provided to it.
RollingStatCalculator(int) - Constructor for class org.apache.hadoop.hbase.util.RollingStatCalculator
Creates a RollingStatCalculator with given number of rolling periods.
rollMetricsPeriod() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
rollMetricsPeriod() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
rollWALWriter(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Roll the log writer.
rollWALWriter(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
rollWALWriter(RpcController, AdminProtos.RollWALWriterRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Roll the WAL writer of the region server.
rollWriter() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
rollWriter(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
rollWriter() - Method in interface org.apache.hadoop.hbase.wal.WAL
Roll the log writer.
rollWriter(boolean) - Method in interface org.apache.hadoop.hbase.wal.WAL
Roll the log writer.
rollWriterForTesting() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
root - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
rootBlockContainingKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
Finds the root-level index block containing the given key.
rootBlockContainingKey(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
Finds the root-level index block containing the given key.
rootDir - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
rootFs - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
ROOTINDEXSIZEKB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
RootResource - Class in org.apache.hadoop.hbase.rest
 
RootResource() - Constructor for class org.apache.hadoop.hbase.rest.RootResource
Constructor
roundRobinAssignment(List<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Generates a bulk assignment plan to be used on cluster startup using a simple round-robin assignment.
roundRobinAssignment(List<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
 
roundRobinAssignment(List<HRegionInfo>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Perform a Round Robin assignment of regions.
roundRobinAssignment(List<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
roundUpToBucketSizeInfo(int) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
Round up the given block size to bucket size, and get the corresponding BucketSizeInfo
row - Variable in class org.apache.hadoop.hbase.client.Mutation
 
row - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
row - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
 
Row - Interface in org.apache.hadoop.hbase.client
Has a row.
row - Variable in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
row to increment
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
row key
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
Row to update
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
key of the row to be completely deleted.
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
key of the row to be completely deleted.
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
Row to update
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
row key
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
row key
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
row key
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
row key
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
row key
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
row key
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
row key
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
row key
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
row key
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
row key
row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
row key
row - Variable in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
row - Variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
row - Variable in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
row - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
row - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
row - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
row to check
row - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
row to check
row - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
row to check
row - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
row - Variable in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
row - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
row - Variable in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
row - Variable in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
ROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
ROW_KEY - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
 
ROW_KEYS_PARAM_NAME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
ROW_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
Size of the row length field in bytes
ROW_OFFSET - Static variable in class org.apache.hadoop.hbase.KeyValue
 
ROW_VALUE - Static variable in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
ROW = 0;
rowBatches - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
list of row batches
rowBatches - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
list of row batches
ROWBATCHSIZE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
rowBuffer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
rowComparator - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
Row comparator for the region this query is for
rowCount(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the row count, by summing up the individual results obtained from regions.
rowCount(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It gives the row count, by summing up the individual results obtained from regions.
RowCountEndpoint - Class in org.apache.hadoop.hbase.coprocessor.example
Sample coprocessor endpoint exposing a Service interface for counting rows and key values.
RowCountEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
 
RowCounter - Class in org.apache.hadoop.hbase.mapred
A job with a map to count rows.
RowCounter() - Constructor for class org.apache.hadoop.hbase.mapred.RowCounter
 
RowCounter - Class in org.apache.hadoop.hbase.mapreduce
A job with a just a map phase to count rows.
RowCounter() - Constructor for class org.apache.hadoop.hbase.mapreduce.RowCounter
 
RowFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on the key.
RowFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.RowFilter
Constructor.
RowIndexCodecV1 - Class in org.apache.hadoop.hbase.io.encoding
Store cells following every row's start offset, so we can binary search to a row's cells.
RowIndexCodecV1() - Constructor for class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
 
RowIndexEncoderV1 - Class in org.apache.hadoop.hbase.io.encoding
 
RowIndexEncoderV1(DataOutputStream, HFileBlockDefaultEncodingContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
 
RowIndexSeekerV1 - Class in org.apache.hadoop.hbase.io.encoding
 
RowIndexSeekerV1(KeyValue.KVComparator, HFileBlockDecodingContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
RowIndexSeekerV1.SeekerState - Class in org.apache.hadoop.hbase.io.encoding
 
RowIndexSeekerV1.SeekerState() - Constructor for class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
rowIsInRange(HRegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Determines if the specified row is within the row range specified by the specified HRegionInfo
rowIsInRange(HRegionInfo, byte[], int, short) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
 
ROWKEY_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
rowLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
rowMatchesAfterCurrentPosition(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
compare this.row to key.row but starting at the current rowLength
RowModel - Class in org.apache.hadoop.hbase.rest.model
Representation of a row.
RowModel() - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
Default constructor
RowModel(String) - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
Constructor
RowModel(byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
Constructor
RowModel(String, List<CellModel>) - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
Constructor
RowModel(byte[], List<CellModel>) - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
Constructor
RowMutations - Class in org.apache.hadoop.hbase.client
Performs multiple mutations atomically on a single row.
RowMutations() - Constructor for class org.apache.hadoop.hbase.client.RowMutations
Constructor for Writable.
RowMutations(byte[]) - Constructor for class org.apache.hadoop.hbase.client.RowMutations
Create an atomic mutation for the specified row.
rowMutations - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
row mutations to execute if the value matches
rowMutationsFromThrift(TRowMutations) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
Creates a RowMutations (HBase) from a TRowMutations (Thrift)
RowNodeReader - Class in org.apache.hadoop.hbase.codec.prefixtree.decode.row
Position one of these appropriately in the data block and you can call its methods to retrieve information necessary to decode the cells in the row.
RowNodeReader() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
rowNodes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
rowNodeStackIndex - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
RowNodeWriter - Class in org.apache.hadoop.hbase.codec.prefixtree.encode.row
Serializes the fields comprising one node of the row trie, which can be a branch, nub, or leaf.
RowNodeWriter(PrefixTreeEncoder, TokenizerNode) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
construct
RowProcessor<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message> - Interface in org.apache.hadoop.hbase.regionserver
Defines the procedure to atomically perform multiple scans and mutations on a HRegion.
RowProcessorClient - Class in org.apache.hadoop.hbase.client.coprocessor
Convenience class that is used to make RowProcessorEndpoint invocations.
RowProcessorClient() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.RowProcessorClient
 
rowRange - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
RowResource - Class in org.apache.hadoop.hbase.rest
 
RowResource(TableResource, String, String, String, String) - Constructor for class org.apache.hadoop.hbase.rest.RowResource
Constructor
rowResultFromHBase(Result[], boolean) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a list of Thrift TRowResult "struct" based on an Hbase RowResult object.
rowResultFromHBase(Result[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a list of Thrift TRowResult "struct" based on an array of Hbase RowResult objects.
rowResultFromHBase(Result) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
 
RowResultGenerator - Class in org.apache.hadoop.hbase.rest
 
RowResultGenerator(String, RowSpec, Filter, boolean) - Constructor for class org.apache.hadoop.hbase.rest.RowResultGenerator
 
rows - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
row keys
rows - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
row keys
rows - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
row keys
rows - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
row keys
ROWS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
ROWSDELETED_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
RowSectionWriter - Class in org.apache.hadoop.hbase.codec.prefixtree.encode.row
Most of the complexity of the PrefixTree is contained in the "row section".
RowSectionWriter() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
construct
RowSectionWriter(PrefixTreeEncoder) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
RowSpec - Class in org.apache.hadoop.hbase.rest
Parses a path based row/column/timestamp specification into its component elements.
RowSpec(String) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
 
RowSpec(byte[], byte[], byte[][], long, long, int) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
 
RowSpec(byte[], byte[], Collection<byte[]>, long, long, int, Collection<String>) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
 
RowSpec(byte[], byte[], Collection<byte[]>, long, long, int) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
 
rowTokenizer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
RowTooBigException - Exception in org.apache.hadoop.hbase.client
Gets or Scans throw this exception if running without in-row scan flag set and row size appears to exceed max configured size (configurable via hbase.table.max.rowsize).
RowTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.client.RowTooBigException
 
RowTooBigException - Exception in org.apache.hadoop.hbase.regionserver
Gets or Scans throw this exception if running without in-row scan flag set and row size appears to exceed max configured size (configurable via hbase.table.max.rowsize).
RowTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RowTooBigException
 
rowToStr(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
 
rowToStr(byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
 
rowToStr(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
rowTreeDepth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
rowWriter - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
RPAREN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for RPAREN
RPC_CALLS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
RPC_CODEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for setting RPC codec class name
RPC_CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
 
RPC_GET_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
RPC_GET_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
RPC_HEADER - Static variable in class org.apache.hadoop.hbase.HConstants
The first four bytes of Hadoop RPC connections
RPC_MULTI_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
RPC_MULTI_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
RPC_MUTATE_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
RPC_MUTATE_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
RPC_RETRIES_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
RPC_SCAN_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
RPC_SCAN_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
RPC_WARN_TIME_KEY - Static variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
RpcCallContext - Interface in org.apache.hadoop.hbase.ipc
 
RpcClient - Interface in org.apache.hadoop.hbase.ipc
Interface for RpcClient implementations so ConnectionManager can handle it.
RpcClientFactory - Class in org.apache.hadoop.hbase.ipc
Factory to create a RpcClient
rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
RpcControllerFactory - Class in org.apache.hadoop.hbase.ipc
Factory to create a HBaseRpcController.
RpcControllerFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
RpcExecutor - Class in org.apache.hadoop.hbase.ipc
Runs the CallRunners passed here via RpcExecutor.dispatch(CallRunner).
RpcExecutor(String, int, int) - Constructor for class org.apache.hadoop.hbase.ipc.RpcExecutor
Deprecated.
RpcExecutor(String, int, int, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RpcExecutor
Deprecated.
RpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RpcExecutor
 
RpcExecutor(String, int, String, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RpcExecutor
 
RpcExecutor.Handler - Class in org.apache.hadoop.hbase.ipc
Handler thread run the CallRunner.run() in.
RpcExecutor.QueueBalancer - Class in org.apache.hadoop.hbase.ipc
 
RpcExecutor.QueueBalancer() - Constructor for class org.apache.hadoop.hbase.ipc.RpcExecutor.QueueBalancer
 
rpcHistograms - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
RpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
Runs an rpc'ing RetryingCallable.
RpcRetryingCaller(long, long, int, int) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCaller
 
RpcRetryingCaller(long, long, int, RetryingCallerInterceptor, int, int) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCaller
 
RpcRetryingCallerFactory - Class in org.apache.hadoop.hbase.client
Factory to create an RpcRetryingCaller
RpcRetryingCallerFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
RpcRetryingCallerFactory(Configuration, RetryingCallerInterceptor) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
 
RpcRetryingCallerWithReadReplicas - Class in org.apache.hadoop.hbase.client
Caller that goes to replica if the primary region does no answer within a configurable timeout.
RpcRetryingCallerWithReadReplicas(RpcControllerFactory, TableName, ClusterConnection, Get, ExecutorService, int, int, int) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
rpcs - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
 
RpcScheduler - Class in org.apache.hadoop.hbase.ipc
An interface for RPC request scheduling algorithm.
RpcScheduler() - Constructor for class org.apache.hadoop.hbase.ipc.RpcScheduler
 
RpcScheduler.Context - Class in org.apache.hadoop.hbase.ipc
Exposes runtime information of a RpcServer that a RpcScheduler may need.
RpcScheduler.Context() - Constructor for class org.apache.hadoop.hbase.ipc.RpcScheduler.Context
 
RpcSchedulerFactory - Interface in org.apache.hadoop.hbase.regionserver
A factory class that constructs an RpcScheduler.
RpcServer - Class in org.apache.hadoop.hbase.ipc
An RPC server that hosts protobuf described Services.
RpcServer(Server, String, List<RpcServer.BlockingServiceAndInterface>, InetSocketAddress, Configuration, RpcScheduler) - Constructor for class org.apache.hadoop.hbase.ipc.RpcServer
Constructs a server listening on the named port and address.
RpcServer.BlockingServiceAndInterface - Class in org.apache.hadoop.hbase.ipc
Datastructure for passing a BlockingService and its associated class of protobuf service interface.
RpcServer.BlockingServiceAndInterface(BlockingService, Class<?>) - Constructor for class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
 
RpcServer.Call - Class in org.apache.hadoop.hbase.ipc
Datastructure that holds all necessary to a method invocation and then afterward, carries the result.
RpcServer.Connection - Class in org.apache.hadoop.hbase.ipc
Reads calls from a connection and queues them for handling.
RpcServer.Connection(SocketChannel, long) - Constructor for class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
RpcServer.Responder - Class in org.apache.hadoop.hbase.ipc
 
RpcServerInterface - Interface in org.apache.hadoop.hbase.ipc
 
rpcServices - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
rpcTimers - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
RS_ENABLE_TABLE_METRICS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
RS_ENABLE_TABLE_METRICS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
RS_LOCK_ZNODE - Static variable in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
Name of znode we use to lock during failover
RS_START_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
RS_START_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
RSDumpServlet - Class in org.apache.hadoop.hbase.regionserver
 
RSDumpServlet() - Constructor for class org.apache.hadoop.hbase.regionserver.RSDumpServlet
 
RSGROUP_TABLE_NAME - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
 
RSGroupableBalancer - Interface in org.apache.hadoop.hbase.rsgroup
Marker Interface.
RSGroupAdmin - Interface in org.apache.hadoop.hbase.rsgroup
Group user API interface used between client and server.
RSGroupAdminEndpoint - Class in org.apache.hadoop.hbase.rsgroup
 
RSGroupAdminEndpoint() - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
RSGroupAdminServer - Class in org.apache.hadoop.hbase.rsgroup
Service to support Region Server Grouping (HBase-6721)
RSGroupAdminServer(MasterServices, RSGroupInfoManager) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
RSGroupBasedLoadBalancer - Class in org.apache.hadoop.hbase.rsgroup
GroupBasedLoadBalancer, used when Region Server Grouping is configured (HBase-6721) It does region balance based on a table's group membership.
RSGroupBasedLoadBalancer() - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
RSGroupBasedLoadBalancer(RSGroupInfoManager) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
RSGroupInfo - Class in org.apache.hadoop.hbase.rsgroup
Stores the group information of region server groups.
RSGroupInfo(String) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
RSGroupInfo(RSGroupInfo) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
RSGroupInfoManager - Interface in org.apache.hadoop.hbase.rsgroup
Interface used to manage RSGroupInfo storage.
RSGroupInfoManagerImpl - Class in org.apache.hadoop.hbase.rsgroup
This is an implementation of RSGroupInfoManager.
RSGroupInfoManagerImpl(MasterServices) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
RSGroupSerDe - Class in org.apache.hadoop.hbase.rsgroup
 
RSGroupSerDe() - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupSerDe
 
rsGroupZNode - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
 
RSRpcServices - Class in org.apache.hadoop.hbase.regionserver
Implements the regionserver RPC services.
RSRpcServices(HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
rss - Variable in class org.apache.hadoop.hbase.regionserver.handler.FinishRegionRecoveringHandler
 
rsServices - Variable in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
 
RSStatusServlet - Class in org.apache.hadoop.hbase.regionserver
 
RSStatusServlet() - Constructor for class org.apache.hadoop.hbase.regionserver.RSStatusServlet
 
RSStatusTmpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
RSStatusTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
RSStatusTmpl(String) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
RSStatusTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
RSStatusTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
RSStatusTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
RSStatusTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.regionserver
 
RSStatusTmplImpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
RSStatusTmplImpl(TemplateManager, RSStatusTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmplImpl
 
rsZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
run() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
 
run(String[]) - Method in class org.apache.hadoop.hbase.client.example.BufferedMutatorExample
 
run(String[]) - Method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample
 
run() - Method in class org.apache.hadoop.hbase.executor.EventHandler
 
run(String[]) - Method in class org.apache.hadoop.hbase.hbtop.HBTop
 
run() - Method in class org.apache.hadoop.hbase.hbtop.screen.Screen
 
run(String[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
Runs the command-line pretty-printer, and returns the desired command exit code (zero for success, non-zero for failure).
run(R) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
Called on completion of the RPC call with the response object, or null in the case of an error.
run() - Method in class org.apache.hadoop.hbase.ipc.CallRunner
 
run(boolean) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController.CancellationCallback
 
run() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor.Handler
 
run() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Responder
 
run() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
run(Mapper<ImmutableBytesWritable, Result, K2, V2>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
Run the application's maps using a thread pool.
run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
run() - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
 
run(String[]) - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine
 
run() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
 
run() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache.RefreshCacheTask
 
run(String[]) - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
 
run(String[]) - Method in class org.apache.hadoop.hbase.migration.UpgradeTo96
 
run(String[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
Pass one or more log file names and formatting options and it will dump out a text version of the contents on stdout.
run(String[]) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool
 
run() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
The HRegionServer sticks in this loop until closed.
run(String[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
 
run() - Method in class org.apache.hadoop.hbase.regionserver.Leases
 
run() - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
 
run() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable
 
run() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.TableMetricsWrapperRunnable
 
run() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
 
run(String[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
 
run() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.ReplicationSourceShipperThread
 
run() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
run() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReaderThread
 
run(String[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
 
run() - Method in class org.apache.hadoop.hbase.rest.RESTDemoClient
 
run() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
run(String[]) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
Execute the export snapshot by copying the snapshot metadata, hfiles and wals.
run(String[]) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Deprecated.
 
run() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
 
run() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
 
run() - Method in class org.apache.hadoop.hbase.thrift2.DemoClient
 
run() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
run(String[]) - Method in class org.apache.hadoop.hbase.tool.CanaryTool
 
run(String[]) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
run() - Method in class org.apache.hadoop.hbase.util.HasThread
 
run(String[]) - Method in class org.apache.hadoop.hbase.util.HFileV1Detector
Checks for HFileV1.
run(String[]) - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
 
run(String[]) - Method in class org.apache.hadoop.hbase.util.Merge
 
run(String[]) - Method in class org.apache.hadoop.hbase.util.ZKDataMigrator
 
run(String[]) - Static method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
Pass one or more log file names and formatting options and it will dump out a text version of the contents on stdout.
run() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.WriterThread
 
run(String[]) - Method in class org.apache.hadoop.hbase.zookeeper.ZkAclReset
 
RUN_MAX_STEPS_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
RUN_SHUTDOWN_HOOK - Static variable in class org.apache.hadoop.hbase.regionserver.ShutdownHook
Key for boolean configuration whose default is true.
runAs(PrivilegedAction<T>) - Method in class org.apache.hadoop.hbase.security.User
Executes the given action within the context of this user.
runAs(PrivilegedExceptionAction<T>) - Method in class org.apache.hadoop.hbase.security.User
Executes the given action within the context of this user.
runAs(PrivilegedAction<T>) - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
 
runAs(PrivilegedExceptionAction<T>) - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
 
runAsLoginUser(PrivilegedExceptionAction<T>) - Static method in class org.apache.hadoop.hbase.security.User
Executes the given action as the login user
runCatalogScan() - Method in interface org.apache.hadoop.hbase.client.Admin
Ask for a scan of the catalog table
runCatalogScan() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Ask for a scan of the catalog table
runCatalogScan(RpcController, MasterProtos.RunCatalogScanRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
runCleaner() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
 
runCleanerChore() - Method in interface org.apache.hadoop.hbase.client.Admin
Ask for cleaner chore to run
runCleanerChore() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
runCleanerChore(RpcController, MasterProtos.RunCleanerChoreRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
runCmdAsync(List<String>) - Static method in class org.apache.hadoop.hbase.util.ProcessUtils
 
runnerStats - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
running - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
RWQueueRpcExecutor - Class in org.apache.hadoop.hbase.ipc
RPC Executor that uses different queues for reads and writes.
RWQueueRpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
RWQueueRpcExecutor(String, int, int, float, int, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
Deprecated.
RWQueueRpcExecutor(String, int, int, float, float, int) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
Deprecated.
RWQueueRpcExecutor(String, int, int, float, float, int, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
Deprecated.
RWQueueRpcExecutor(String, int, int, float, int, Configuration, Abortable, Class<? extends BlockingQueue>, Object...) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
Deprecated.
RWQueueRpcExecutor(String, int, int, float, float, int, Configuration, Abortable, Class<? extends BlockingQueue>, Object...) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
Deprecated.
RWQueueRpcExecutor(String, int, int, float, float, Class<? extends BlockingQueue>, Object[], Class<? extends BlockingQueue>, Object[]) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
Deprecated.
RWQueueRpcExecutor(String, int, int, int, int, Class<? extends BlockingQueue>, Object[], Class<? extends BlockingQueue>, Object[]) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
Deprecated.
RWQueueRpcExecutor(String, int, int, int, int, float, Class<? extends BlockingQueue>, Object[], Class<? extends BlockingQueue>, Object[]) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
Deprecated.

S

S - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'S'
safeGetHeapMemoryUsage() - Static method in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
Return JVM memory statistics while properly handling runtime exceptions from the JVM.
SampleUploader - Class in org.apache.hadoop.hbase.mapreduce
Sample Uploader MapReduce
SampleUploader() - Constructor for class org.apache.hadoop.hbase.mapreduce.SampleUploader
 
sanityCheckLeft(byte[], byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
Subclasses can call this method to make sure the first KV is within multi-writer range.
sanityCheckRight(byte[], byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
Subclasses can call this method to make sure the last KV is within multi-writer range.
sanityCheckUncompressedSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
An additional sanity-check in case no compression or encryption is being used.
SASL_DEFAULT_REALM - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
 
SaslChallengeDecoder - Class in org.apache.hadoop.hbase.security
Decode the sasl challenge sent by RpcServer.
SaslChallengeDecoder() - Constructor for class org.apache.hadoop.hbase.security.SaslChallengeDecoder
 
saslClient - Variable in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
saslConnect(InputStream, OutputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
Do client side SASL authentication with server via the given InputStream and OutputStream
saslLatch - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
saslProps - Variable in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
SaslStatus - Enum in org.apache.hadoop.hbase.security
 
SaslUnwrapHandler - Class in org.apache.hadoop.hbase.security
Unwrap sasl messages.
SaslUnwrapHandler(SaslClient) - Constructor for class org.apache.hadoop.hbase.security.SaslUnwrapHandler
 
SaslUtil - Class in org.apache.hadoop.hbase.security
 
SaslUtil() - Constructor for class org.apache.hadoop.hbase.security.SaslUtil
 
SaslUtil.QualityOfProtection - Enum in org.apache.hadoop.hbase.security
 
SaslWrapHandler - Class in org.apache.hadoop.hbase.security
wrap sasl messages.
SaslWrapHandler(SaslClient) - Constructor for class org.apache.hadoop.hbase.security.SaslWrapHandler
 
saveMetadata(HFile.Writer) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Save metadata in HFile which will be written to disk
saveMetadata(HFile.Writer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
saveMetadata(HFile.Writer) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
scan - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
Scan - Class in org.apache.hadoop.hbase.client
Used to perform Scan operations.
Scan() - Constructor for class org.apache.hadoop.hbase.client.Scan
Create a Scan operation across all rows.
Scan(byte[], Filter) - Constructor for class org.apache.hadoop.hbase.client.Scan
Deprecated.
use new Scan().withStartRow(startRow).setFilter(filter) instead.
Scan(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
Deprecated.
use new Scan().withStartRow(startRow) instead.
Scan(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
Deprecated.
use new Scan().withStartRow(startRow).withStopRow(stopRow) instead.
Scan(Scan) - Constructor for class org.apache.hadoop.hbase.client.Scan
Creates a new instance of this class while copying all values.
Scan(Get) - Constructor for class org.apache.hadoop.hbase.client.Scan
Builds a scan object with the same specs as get.
scan - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
SCAN - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Base-64 encoded scanner.
scan(RpcController, ClientProtos.ScanRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Scan data in a table.
scan - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
scan - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
Scan instance
Scan.ReadType - Enum in org.apache.hadoop.hbase.client
 
SCAN_ATTRIBUTES_METRICS_DATA - Static variable in class org.apache.hadoop.hbase.client.Scan
Deprecated.
SCAN_ATTRIBUTES_METRICS_ENABLE - Static variable in class org.apache.hadoop.hbase.client.Scan
Deprecated.
SCAN_ATTRIBUTES_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.client.Scan
 
SCAN_BATCH_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_BATCHSIZE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Set the maximum number of values to return for each call to next().
SCAN_CACHE_BLOCKS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_CACHEBLOCKS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Set to false to disable server-side caching of blocks for this scan.
SCAN_CACHEDROWS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The number of rows for caching that will be passed to scanners.
SCAN_COLUMN - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_COLUMN_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Column Family to Scan
SCAN_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Space delimited list of columns and column families to scan.
SCAN_END_ROW - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_END_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_FETCH_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
SCAN_FILTER - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SCAN_LIMIT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_MAX_VERSIONS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_MAXVERSIONS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The maximum number of version to return.
SCAN_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
SCAN_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
SCAN_REVERSED - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_ROW_START - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Scan start row
SCAN_ROW_STOP - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Scan stop row
SCAN_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
 
SCAN_SIZE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SCAN_START_ROW - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_START_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
SCAN_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
 
SCAN_TIME_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SCAN_TIMERANGE_END - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The ending timestamp used to filter columns with a specific range of versions.
SCAN_TIMERANGE_START - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The starting timestamp used to filter columns with a specific range of versions.
SCAN_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The timestamp used to filter columns with a specific timestamp.
SCAN_VTIME_WEIGHT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
Used to control the scan delay, currently sqrt(numNextCall * weight)
ScanDeleteTracker - Class in org.apache.hadoop.hbase.regionserver.querymatcher
This class is responsible for the tracking and enforcement of Deletes during the course of a Scan operation.
ScanDeleteTracker() - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
scanFromThrift(TScan) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
 
ScanInfo - Class in org.apache.hadoop.hbase.regionserver
Immutable information for scans over a store.
ScanInfo(Configuration, HColumnDescriptor, long, long, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanInfo
 
ScanInfo(Configuration, byte[], int, int, long, KeepDeletedCells, long, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanInfo
 
ScanLabelGenerator - Interface in org.apache.hadoop.hbase.security.visibility
This would be the interface which would be used add labels to the RPC context and this would be stored against the UGI.
scanMetrics - Variable in class org.apache.hadoop.hbase.client.AbstractClientScanner
 
ScanMetrics - Class in org.apache.hadoop.hbase.client.metrics
Provides metrics related to scan operations (both server side and client side metrics).
ScanMetrics() - Constructor for class org.apache.hadoop.hbase.client.metrics.ScanMetrics
constructor
scanMetrics - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
scanMetricsPublished - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
scannerCaching - Variable in class org.apache.hadoop.hbase.client.HTable
 
ScannerCallable - Class in org.apache.hadoop.hbase.client
Scanner operations such as create, next, etc.
ScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallable
 
ScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory, int) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallable
 
scannerClose(int, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
scannerClose(int, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerClose(int) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Closes the server-state associated with an open scanner.
scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
ScannerContext - Class in org.apache.hadoop.hbase.regionserver
ScannerContext instances encapsulate limit tracking AND progress towards those limits during invocations of InternalScanner.next(java.util.List) and InternalScanner.next(java.util.List).
ScannerContext.Builder - Class in org.apache.hadoop.hbase.regionserver
 
ScannerContext.LimitScope - Enum in org.apache.hadoop.hbase.regionserver
The various scopes where a limit can be enforced.
ScannerContext.NextState - Enum in org.apache.hadoop.hbase.regionserver
The possible states a scanner may be in following a call to InternalScanner.next(List)
scannerGet(int, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
scannerGet(int, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerGet(int) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Returns the scanner's current row value and advances to the next row in the table.
scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
scannerGetList(int, int, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
scannerGetList(int, int, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
scannerGetList(int, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerGetList(int, int) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Returns, starting at the scanner's current row value nbRows worth of rows and advances to the next row in the table.
scannerGetList(int, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
scannerId - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
scannerId - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
the Id of the Scanner to close *
scannerId - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
the Id of the Scanner to return rows from.
ScannerIdGenerator - Class in org.apache.hadoop.hbase.regionserver
Generate a new style scanner id to prevent collision with previous started server or other RSs.
ScannerIdGenerator(ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.ScannerIdGenerator
 
ScannerInstanceResource - Class in org.apache.hadoop.hbase.rest
 
ScannerInstanceResource() - Constructor for class org.apache.hadoop.hbase.rest.ScannerInstanceResource
 
ScannerInstanceResource(String, String, ResultGenerator, int) - Constructor for class org.apache.hadoop.hbase.rest.ScannerInstanceResource
 
scannerMap - Variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
scannerMaxResultSize - Variable in class org.apache.hadoop.hbase.client.HTable
 
ScannerMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
ScannerMessage.Scanner - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.Scanner
ScannerMessage.Scanner.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.Scanner
ScannerMessage.ScannerOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
ScannerModel - Class in org.apache.hadoop.hbase.rest.model
A representation of Scanner parameters.
ScannerModel() - Constructor for class org.apache.hadoop.hbase.rest.model.ScannerModel
Default constructor
ScannerModel(byte[], byte[], List<byte[]>, int, int, long, int, String) - Constructor for class org.apache.hadoop.hbase.rest.model.ScannerModel
Constructor
ScannerModel(byte[], byte[], List<byte[]>, int, int, long, long, String) - Constructor for class org.apache.hadoop.hbase.rest.model.ScannerModel
Constructor
scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get a scanner on the current table starting at the specified row and ending at the last row in the table.
scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get a scanner on the current table starting at the specified row and ending at the last row in the table.
scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Open a scanner for a given prefix.
scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get a scanner on the current table, using the Scan instance for the scan parameters.
scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get a scanner on the current table starting and stopping at the specified rows.
scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
 
scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
 
scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
Get a scanner on the current table starting and stopping at the specified rows.
scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
ScannerResetException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when the server side has received an Exception, and asks the Client to reset the scanner state by closing the current region scanner, and reopening from the start of last seen row.
ScannerResetException() - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
constructor
ScannerResetException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
Constructor
ScannerResetException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
 
scannerResetException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
scannerResetException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
ScannerResource - Class in org.apache.hadoop.hbase.rest
 
ScannerResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResource
Constructor
ScannerResultGenerator - Class in org.apache.hadoop.hbase.rest
 
ScannerResultGenerator(String, RowSpec, Filter, boolean) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
ScannerResultGenerator(String, RowSpec, Filter, int, boolean) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
scannerTimeout - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
ScannerTimeoutException - Exception in org.apache.hadoop.hbase.client
Thrown when a scanner has timed out.
ScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
A query matcher that is specifically designed for the scan case.
ScanQueryMatcher(Cell, ScanInfo, ColumnTracker, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
ScanQueryMatcher.MatchCode - Enum in org.apache.hadoop.hbase.regionserver.querymatcher
ScanResultCache - Class in org.apache.hadoop.hbase.client
Used to separate the row constructing logic.
SCANS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
Job parameter that specifies the scan list.
scanTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
ScanType - Enum in org.apache.hadoop.hbase.regionserver
Enum to distinguish general scan types.
ScanWildcardColumnTracker - Class in org.apache.hadoop.hbase.regionserver.querymatcher
Keeps track of the columns for a scan if they are not explicitly specified
ScanWildcardColumnTracker(int, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
Return maxVersions of every row.
scheduleChore(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
 
ScheduledChore - Class in org.apache.hadoop.hbase
ScheduledChore is a task performed on a period in hbase.
ScheduledChore() - Constructor for class org.apache.hadoop.hbase.ScheduledChore
This constructor is for test only.
ScheduledChore(String, Stoppable, int) - Constructor for class org.apache.hadoop.hbase.ScheduledChore
 
ScheduledChore(String, Stoppable, int, long) - Constructor for class org.apache.hadoop.hbase.ScheduledChore
 
ScheduledChore(String, Stoppable, int, long, TimeUnit) - Constructor for class org.apache.hadoop.hbase.ScheduledChore
 
SchemaResource - Class in org.apache.hadoop.hbase.rest
 
SchemaResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.SchemaResource
Constructor
scopeWALEdits(HTableDescriptor, WALKey, WALEdit, Configuration, ReplicationSourceManager) - Static method in class org.apache.hadoop.hbase.replication.regionserver.Replication
Utility method used to set the correct scopes on each log key.
ScopeWALEntryFilter - Class in org.apache.hadoop.hbase.replication
Keeps KVs that are scoped other than local
ScopeWALEntryFilter() - Constructor for class org.apache.hadoop.hbase.replication.ScopeWALEntryFilter
 
Screen - Class in org.apache.hadoop.hbase.hbtop.screen
This dispatches key presses and timers to the current ScreenView.
Screen(Configuration, long, Mode) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.Screen
 
ScreenBuffer - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
Represents a buffer of the terminal screen for double-buffering.
ScreenBuffer() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
 
ScreenView - Interface in org.apache.hadoop.hbase.hbtop.screen
An interface for a screen view that handles key presses and timers.
second - Variable in class org.apache.hadoop.hbase.util.Pair
 
secretManager - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
SecureBulkLoadClient - Class in org.apache.hadoop.hbase.client.coprocessor
Client proxy for SecureBulkLoadProtocol used in conjunction with SecureBulkLoadEndpoint
SecureBulkLoadClient(Table) - Constructor for class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
SecureBulkLoadEndpoint - Class in org.apache.hadoop.hbase.security.access
Coprocessor service for bulk loads in secure mode.
SecureBulkLoadEndpoint() - Constructor for class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
 
secureBulkLoadHFiles(RpcController, SecureBulkLoadProtos.SecureBulkLoadHFilesRequest, RpcCallback<SecureBulkLoadProtos.SecureBulkLoadHFilesResponse>) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
 
SecureBulkLoadUtil - Class in org.apache.hadoop.hbase.security
 
SecureBulkLoadUtil() - Constructor for class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
 
SecureProtobufLogReader - Class in org.apache.hadoop.hbase.regionserver.wal
 
SecureProtobufLogReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
 
SecureProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
 
SecureProtobufLogWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogWriter
 
SecureWALCellCodec - Class in org.apache.hadoop.hbase.regionserver.wal
A WALCellCodec that encrypts the WALedits.
SecureWALCellCodec(Configuration, CompressionContext) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
 
SecureWALCellCodec(Configuration, Encryptor) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
 
SecureWALCellCodec(Configuration, Decryptor) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
 
SecurityCapability - Enum in org.apache.hadoop.hbase.client.security
Available security capabilities
SecurityInfo - Class in org.apache.hadoop.hbase.security
Maps RPC protocol interfaces to required configuration
SecurityInfo(String, AuthenticationProtos.TokenIdentifier.Kind) - Constructor for class org.apache.hadoop.hbase.security.SecurityInfo
 
SecurityUtil - Class in org.apache.hadoop.hbase.security
Security related generic utility methods.
SecurityUtil() - Constructor for class org.apache.hadoop.hbase.security.SecurityUtil
 
seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
Set the scanner at the seek key.
seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Seeks all scanners at or below the specified seek key.
seek(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Seek the scanner at or after the specified KeyValue.
seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
 
seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
seek(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
seek(Cell) - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
seek(long) - Method in interface org.apache.hadoop.hbase.wal.WAL.Reader
 
seekAsDirection(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
Do a reseek in a normal StoreScanner(scan forward)
seekAtOrAfter(HFileScanner, Cell) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
seekBefore(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
seekBefore(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
seekBefore(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
seekBefore(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Deprecated.
seekBefore(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Deprecated.
seekBefore(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
seekForwardTo(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
 
seekForwardTo(Cell) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.scanner.CellSearcher
Note: Added for backwards compatibility with KeyValueScanner.reseek(org.apache.hadoop.hbase.Cell)
seekForwardToOrAfter(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
 
seekForwardToOrAfter(Cell) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.scanner.CellSearcher
Same as seekForwardTo(..), but go to the extra effort of finding the next key if there's no exact match.
seekForwardToOrBefore(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
 
seekForwardToOrBefore(Cell) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.scanner.CellSearcher
Same as seekForwardTo(..), but go to the extra effort of finding the next key if there's no exact match.
seekOnFs(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
seekOnFs(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
Performs a filesystem-level seek to a certain position in an underlying file.
seekOnFs(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
seekScanners(List<? extends KeyValueScanner>, Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
Seek the specified scanners with the given key
seekTo(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
seekTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
seekTo(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
seekTo(Cell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
An internal API function.
seekTo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
seekTo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
Positions this scanner at the start of the file.
seekTo(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Deprecated.
seekTo(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Deprecated.
seekTo(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
seekTo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Positions this scanner at the start of the file.
seekToDataBlock(Cell, HFileBlock, boolean, boolean, boolean, DataBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
Return the data block which contains this key.
seekToKeyInBlock(byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
Seek forward only (should be called reseekToKeyInBlock?).
seekToKeyInBlock(Cell, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
seekToKeyInBlock(byte[], int, int, boolean) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
Deprecated.
seekToKeyInBlock(Cell, boolean) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
Moves the seeker position within the current block to: the last key that that is less than or equal to the given key if seekBefore is false the last key that is strictly less than the given key if seekBefore is true.
seekToKeyInBlock(byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
seekToKeyInBlock(Cell, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
 
seekToLastRow() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Seek the scanner at the first KeyValue of last row
seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
 
seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
 
seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
seekToNextRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
seekToOrBeforeUsingPositionAtOrAfter(byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
seekToOrBeforeUsingPositionAtOrAfter(Cell, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
seekToOrBeforeUsingPositionAtOrBefore(byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
seekToOrBeforeUsingPositionAtOrBefore(Cell, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
Separately get the KeyValue before the specified key from kvset and snapshotset, and use the row of higher one as the previous row of specified key, then seek to the first KeyValue of previous row
seekToPreviousRow(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Seek the scanner at the first Cell of the row which is the previous row of specified key
seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
 
seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
 
seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
select(List<StoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
Called to select files for compaction.
selectCompaction(Collection<StoreFile>, List<StoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.FIFOCompactionPolicy
 
selectCompaction(Collection<StoreFile>, List<StoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
 
selectCompaction(StripeCompactionPolicy.StripeInformationProvider, List<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
 
selectFlush(KeyValue.KVComparator, StripeCompactionPolicy.StripeInformationProvider, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
 
selectMajorCompaction(ArrayList<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
 
selectMinorCompaction(ArrayList<StoreFile>, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
We receive store files sorted in ascending order by seqId then scan the list of files.
SELECTOR_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
Number of selector threads for reading and writing socket
selectScannersFrom(List<? extends KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
Filters the given list of scanners using Bloom filter, time range, and TTL.
selectSingleStripeCompaction(StripeCompactionPolicy.StripeInformationProvider, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
 
selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushAllStoresPolicy
 
selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
 
selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushPolicy
 
selectToken(Text, Collection<Token<? extends TokenIdentifier>>) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
 
send_append(TAppend) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_append(ByteBuffer, TAppend) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_checkAndMutate(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TCompareOp, ByteBuffer, TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_closeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_compact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_createTable(ByteBuffer, List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_deleteMultiple(ByteBuffer, List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_deleteSingle(ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_deleteTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_disableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_enableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_exists(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_existsAll(ByteBuffer, List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_get(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_getAllRegionLocations(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_getColumnDescriptors(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getMultiple(ByteBuffer, List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_getRegionInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getRegionLocation(ByteBuffer, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getScannerResults(ByteBuffer, TScan, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_getScannerRows(int, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_getTableNames() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getTableRegions(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_increment(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_increment(ByteBuffer, TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_incrementRows(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_isTableEnabled(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_majorCompact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_mutateRow(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_mutateRow(ByteBuffer, TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_mutateRows(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_mutateRowsTs(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_mutateRowTs(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_openScanner(ByteBuffer, TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_put(ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_putMultiple(ByteBuffer, List<TPut>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerGetList(int, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
send_scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
 
sendAbortProcessSignal() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
 
sendAbortToMembers(Procedure, ForeignException) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
Notify the members that the coordinator has aborted the procedure and that it should release barrier resources.
sendAbortToMembers(Procedure, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
This is the abort message being sent by the coordinator to member TODO this code isn't actually used but can be used to issue a cancellation from the coordinator.
sendError(int, String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
sendError(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
sendError(int, String) - Method in interface org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.HttpInteraction
Called by the filter after it decides that the request is a potential CSRF attack and therefore must be rejected.
sendGlobalBarrierAcquire(Procedure, byte[], List<String>) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
Notify the members to acquire barrier for the procedure
sendGlobalBarrierAcquire(Procedure, byte[], List<String>) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
The "acquire" phase.
sendGlobalBarrierComplete() - Method in class org.apache.hadoop.hbase.procedure.Procedure
Sends a message to members that all Subprocedure.insideBarrier() calls have completed.
sendGlobalBarrierReached() - Method in class org.apache.hadoop.hbase.procedure.Procedure
Sends a message to all members that the global barrier condition has been satisfied.
sendGlobalBarrierReached(Procedure, List<String>) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
Notify members that all members have acquired their parts of the barrier and that they can now execute under the global barrier.
sendGlobalBarrierReached(Procedure, List<String>) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
 
sendGlobalBarrierStart() - Method in class org.apache.hadoop.hbase.procedure.Procedure
Sends a message to Members to create a new Subprocedure for this Procedure and execute the Subprocedure.acquireBarrier() step.
sendMemberAborted(Subprocedure, ForeignException) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
Notify the coordinator that we aborted the specified Subprocedure
sendMemberAborted(Subprocedure, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
This should be called by the member and should write a serialized root cause exception as to the abort znode.
sendMemberAcquired(Subprocedure) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
Notify the coordinator that the specified Subprocedure has acquired the locally required barrier condition.
sendMemberAcquired(Subprocedure) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
This attempts to create an acquired state znode for the procedure (snapshot name).
sendMemberCompleted(Subprocedure, byte[]) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
Notify the coordinator that the specified Subprocedure has completed the work that needed to be done under the global barrier.
sendMemberCompleted(Subprocedure, byte[]) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
This acts as the ack for a completed procedure
sendPostSyncSignal() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
 
sendRedirect(String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
sendRegionClose(ServerName, HRegionInfo, int, ServerName, boolean) - Method in class org.apache.hadoop.hbase.master.ServerManager
Sends an CLOSE RPC to the specified server to close the specified region.
sendRegionClose(ServerName, HRegionInfo, int) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
sendRegionOpen(ServerName, HRegionInfo, int, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.ServerManager
Sends an OPEN RPC to the specified server to open the specified region.
sendRegionOpen(ServerName, List<Triple<HRegionInfo, Integer, List<ServerName>>>) - Method in class org.apache.hadoop.hbase.master.ServerManager
Sends an OPEN RPC to the specified server to open the specified region.
sendRegionsMerge(ServerName, HRegionInfo, HRegionInfo, boolean, User) - Method in class org.apache.hadoop.hbase.master.ServerManager
Sends an MERGE REGIONS RPC to the specified server to merge the specified regions.
sendRegionWarmup(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.master.ServerManager
Sends a WARMUP RPC to the specified server to warmup the specified region.
sendResponseIfReady() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
sendShutdownInterrupt() - Method in class org.apache.hadoop.hbase.master.HMaster
 
sendShutdownInterrupt() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Called on stop/abort before closing the cluster connection and meta locator.
SENT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
SENT_BYTES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
sentBytes(long) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
sentBytes(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
sentResponse(long) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
sentResponse(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
separator() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
 
separator() - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
 
separator() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
SEPARATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
SEQ_ID - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Comparators
Comparator that compares based on the Sequence Ids of the the StoreFiles.
SEQ_ID_MAX_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Comparators
Comparator for time-aware compaction.
seqids - Static variable in class org.apache.hadoop.hbase.executor.EventHandler
 
SEQNUM_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The open seqnum column qualifier
SEQNUM_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The open seqnum column qualifier
SequenceFileLogReader - Class in org.apache.hadoop.hbase.regionserver.wal
 
SequenceFileLogReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
SequenceId - Interface in org.apache.hadoop.hbase.regionserver
Interface which abstracts implementations on log sequenceId assignment
sequenceID - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
sequenceIdChecker - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
 
sequenceNumber - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
SequentialProcedure<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
A SequentialProcedure describes one step in a procedure chain.
SequentialProcedure() - Constructor for class org.apache.hadoop.hbase.procedure2.SequentialProcedure
 
serialize(String, Throwable) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
Converts a ForeignException to an array of bytes.
serialize(ByteBuffer, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
Serializes its data into destination.
serialize(ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
serialize(KeyValue) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
 
serialize(String, Throwable) - Static method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
Converts a RemoteProcedureException to an array of bytes.
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
The user-level code of the procedure may have some state to persist (e.g.
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureInMemoryChore
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.procedure2.SequentialProcedure
 
serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
 
serve() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
 
server - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
server - Variable in class org.apache.hadoop.hbase.executor.EventHandler
 
server - Variable in class org.apache.hadoop.hbase.master.AssignmentManager
 
server - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.AssignRegionAction
 
server - Variable in class org.apache.hadoop.hbase.master.BulkAssigner
 
Server - Interface in org.apache.hadoop.hbase
Defines the set of shared functions implemented by HBase servers (Masters and RegionServers).
SERVER_NAME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
SERVER_NAME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SERVER_NAME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
SERVER_NAME_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SERVER_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The server column qualifier
SERVER_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The server column qualifier
serverAdded(ServerName) - Method in interface org.apache.hadoop.hbase.master.ServerListener
The server has joined the cluster.
serverAdded(ServerName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
ServerCommandLine - Class in org.apache.hadoop.hbase.util
Base class for command lines that start up various HBase daemons.
ServerCommandLine() - Constructor for class org.apache.hadoop.hbase.util.ServerCommandLine
 
ServerConfigurationKeys - Interface in org.apache.hadoop.hbase.http
This interface contains constants for configuration keys used in the hbase http server code.
ServerCrashProcedure - Class in org.apache.hadoop.hbase.master.procedure
Handle crashed server.
ServerCrashProcedure(MasterProcedureEnv, ServerName, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
Call this constructor queuing up a Procedure.
ServerCrashProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
Used when deserializing from a procedure store; we'll construct one of these then call ServerCrashProcedure.deserializeStateData(InputStream).
serverHasTooFewRegions(int) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
Returns true iff a given server has less regions than the balanced amount
ServerListener - Interface in org.apache.hadoop.hbase.master
Get notification of server registration events.
ServerLoad - Class in org.apache.hadoop.hbase
This class is used for exporting current state of load on a RegionServer.
ServerLoad(ClusterStatusProtos.ServerLoad) - Constructor for class org.apache.hadoop.hbase.ServerLoad
 
serverLoad - Variable in class org.apache.hadoop.hbase.ServerLoad
 
ServerManager - Class in org.apache.hadoop.hbase.master
The ServerManager class manages info about region servers.
ServerManager(Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.ServerManager
Constructor.
serverManager - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
ServerMetricsTmpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
ServerMetricsTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
 
ServerMetricsTmpl(String) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
 
ServerMetricsTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
 
ServerMetricsTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
ServerMetricsTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.ImplData
 
ServerMetricsTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.regionserver
 
ServerMetricsTmplImpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
ServerMetricsTmplImpl(TemplateManager, ServerMetricsTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmplImpl
 
serverName - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
The server name the Master sees us as.
ServerName - Class in org.apache.hadoop.hbase
Instance of an HBase ServerName.
serverName - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
serverName - Variable in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
SERVERNAME_PATTERN - Static variable in class org.apache.hadoop.hbase.ServerName
 
SERVERNAME_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
 
SERVERNAME_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The serverName column qualifier.
SERVERNAME_SEPARATOR - Static variable in class org.apache.hadoop.hbase.ServerName
This character is used as separator between server hostname, port and startcode.
ServerNonceManager - Class in org.apache.hadoop.hbase.regionserver
Implementation of nonce manager that stores nonces in a hash map and cleans them up after some time; if nonce group/client ID is supplied, nonces are stored by client ID.
ServerNonceManager(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.ServerNonceManager
 
ServerNotRunningYetException - Exception in org.apache.hadoop.hbase.ipc
 
ServerNotRunningYetException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerNotRunningYetException
 
serverOffline(ZooKeeperWatcher, ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
A server is offline, all regions on it are dead.
ServerProcedureInterface - Interface in org.apache.hadoop.hbase.master.procedure
Procedures that handle servers -- e.g.
ServerProcedureInterface.ServerOperationType - Enum in org.apache.hadoop.hbase.master.procedure
 
ServerRegionReplicaUtil - Class in org.apache.hadoop.hbase.util
Similar to RegionReplicaUtil but for the server side
ServerRegionReplicaUtil() - Constructor for class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
 
serverRemoved(ServerName) - Method in interface org.apache.hadoop.hbase.master.ServerListener
The server was removed from the cluster.
serverRemoved(ServerName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
ServerRpcController - Class in org.apache.hadoop.hbase.ipc
Used for server-side protobuf RPC service invocations.
ServerRpcController() - Constructor for class org.apache.hadoop.hbase.ipc.ServerRpcController
 
servers - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
servers - Variable in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
 
ServerSideScanMetrics - Class in org.apache.hadoop.hbase.client.metrics
Provides server side metrics related to scan operations.
ServerSideScanMetrics() - Constructor for class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
ServerStatistics - Class in org.apache.hadoop.hbase.client.backoff
Track the statistics for a single region
ServerStatistics() - Constructor for class org.apache.hadoop.hbase.client.backoff.ServerStatistics
 
ServerStatistics.RegionStatistics - Class in org.apache.hadoop.hbase.client.backoff
 
ServerStatistics.RegionStatistics() - Constructor for class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
ServerStatisticTracker - Class in org.apache.hadoop.hbase.client
Tracks the statistics for multiple regions
ServerStatisticTracker() - Constructor for class org.apache.hadoop.hbase.client.ServerStatisticTracker
 
serverStats - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
ServerTooBusyException - Exception in org.apache.hadoop.hbase.ipc
Throw this in rpc call if there are too many pending requests for one region server
ServerTooBusyException(InetSocketAddress, long) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerTooBusyException
 
SERVERVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
service - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
service - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
service(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.RESTServletContainer
This container is used only if authentication and impersonation is enabled.
services - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
services - Variable in class org.apache.hadoop.hbase.regionserver.LogRoller
 
services - Static variable in class org.apache.hadoop.hbase.security.HBasePolicyProvider
 
set(TokenizerRowSearchPosition, TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
 
set(String, String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
set(Attributes) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
set(Cell) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
set(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
set(long, TimeUnit) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
Set the RateLimiter max available resources and refill period.
set(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
set(byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
set(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
set(byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
set(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Reuse this ByteRange over a new byte[].
set(byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Reuse this ByteRange over a new byte[].
set(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Reuse this ByteRange over a new byte[].
set(byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes
 
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes
 
set(long) - Method in class org.apache.hadoop.hbase.util.Counter
 
set(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
set(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
set(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
set(int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
set(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
set(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
set(int, E) - Method in class org.apache.hadoop.hbase.util.SortedList
 
setAbortFailure(String, String) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Append
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Append
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Delete
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Delete
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Get
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Get
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Increment
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Increment
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Mutation
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Mutation
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Put
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Put
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Query
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Query
 
setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Scan
 
setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Scan
 
setACL(AccessControlList) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
setAcl(String, List<ACL>, int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
setAcl is an idempotent operation.
setActions(Permission.Action[]) - Method in class org.apache.hadoop.hbase.security.access.Permission
 
setAgeOfLastAppliedOp(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
Set the age of the last applied operation
setAgeOfLastShippedOp(long, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Set the age of the last edit that was shipped
setAgeOfLastShippedOpByTable(long, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Set the age of the last edit that was shipped group by table
setAllowed(boolean) - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
setAllowPartialResults(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Setting whether the caller wants to see the partial results when server returns less-than-expected cells.
setAllSameType(byte) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setAllSameType(boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setAllTypes(byte) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setAmmount(long) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
setAmmountIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
setAmount(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
setAmountIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
setAppDir(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
setAppend(TAppend) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
The single append operation to apply
setAppendIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
setArchiveTables(List<String>) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
Set the tables to be archived.
setArrayOffset(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setAssignmentManager(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
 
setAssignmentManager(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
setAssignmentManager(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Append
 
setAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.client.Attributes
Sets an attribute.
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
 
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Get
 
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Increment
 
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
 
setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
 
setAttribute(String, Object) - Method in class org.apache.hadoop.hbase.http.HttpServer
Set a value in the webapp context.
setAttribute(String, Object) - Method in class org.apache.hadoop.hbase.http.InfoServer
 
setAttributes(Attributes) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
Mutation attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
Delete attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
Delete attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
Delete attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
Delete attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
Get attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
Get attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
Get attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
Get attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
Get attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
Get attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
Get attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
Get attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
Get attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
Get attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
Get attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
Mutation attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
Mutation attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
Mutation attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
Mutation attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
Scan attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
Scan attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
Scan attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
Scan attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
Scan attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Scan attributes
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
setAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
setAttrs(int, TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
setAttrs(int, TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Get
 
setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Query
Sets the authorizations to be used by this Query
setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Scan
 
setAuthorizations(TAuthorization) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setAuthorizations(TAuthorization) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setAuthorizationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setAuthorizationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setAuths(byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
setAuths(Configuration, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
setAuths(Connection, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
Sets given labels globally authorized for the user.
setAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
setAuths(byte[], List<byte[]>) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
Sets given labels globally authorized for the user.
setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
setAutoFlush(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Turns 'auto-flush' on or off.
setAutoFlush(boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
in 0.96. When called with setAutoFlush(false), this function also set clearBufferOnFail to true, which is unexpected but kept for historical reasons. Replace it with setAutoFlush(false, false) if this is exactly what you want, though this is the method you want for most cases.
setAutoFlush(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
in 0.99 since setting clearBufferOnFail is deprecated. Use HTableInterface.setAutoFlush(boolean)} instead.
setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
setAutoFlush(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
setAutoFlushTo(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Set the autoFlush behavior, without changing the value of clearBufferOnFail.
setAutoFlushTo(boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
in 0.99 since setting clearBufferOnFail is deprecated. Use HTableInterface.setAutoFlush(boolean) instead, or better still, move on to BufferedMutator
setAutoFlushTo(boolean) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
setAverageLoad(double) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
setAverageLoad(double) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional double averageLoad = 5;
setBackgroundColor(Color) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
setBackoffPolicy(RetryCounter.BackoffPolicy) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
 
setBalancerOn(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.LoadBalancerTracker
Set the balancer on/off
setBalancerRunning(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Turn the load balancer on or off.
setBalancerRunning(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Turn the load balancer on or off.
setBalancerRunning(RpcController, MasterProtos.SetBalancerRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
setBandwidth(double) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
 
setBandwidth(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
setBatch(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set the maximum number of cells to return for each call to next().
setBatch(int) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
setBatch(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 batch = 4;
setBatchLimit(int) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
 
setBatchSize(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setBatchSize(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setBatchSizeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setBatchSizeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setBcn(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
 
setBcn(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
setBcn(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
setBcv(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
 
setBcv(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
setBcv(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
setBindAddress(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
Deprecated.
setBlink(boolean) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setBlockCacheEnabledIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setBlockCacheSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
 
setBlockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
setBlocksize(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setBloomFilterNbHashes(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setBloomFilterNbHashesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setBloomFilterType(String) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setBloomFilterTypeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setBloomFilterVectorSize(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setBloomFilterVectorSizeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setBody(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
 
setBold(boolean) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
setBufferOffset(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setBuilder(Tokenizer) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setBulkLoaded(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
setBulkToken(String) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
Called from replication sink, where it manages bulkToken(staging directory) by itself.
setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Get
Set whether blocks should be cached for this Get.
setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Set whether blocks should be cached for this Scan.
setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bool cacheBlocks = 11;
setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setCacheBlocksIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setCacheBlocksIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setCacheBloomsOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setCacheConfig(CacheConfig) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.ImplData
 
setCacheConfig(CacheConfig) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
 
setCacheDataInL1(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setCacheDataInL1(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Only used for testing.
setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Only used for testing.
setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setCacheMissCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
setCacheOff() - Method in interface org.apache.hadoop.hbase.TableDescriptors
Disables the tabledescriptor cache
setCacheOff() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
 
setCacheOn() - Method in interface org.apache.hadoop.hbase.TableDescriptors
Enables the tabledescriptor cache
setCacheOn() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
 
setCaching(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set the number of rows for caching that will be passed to scanners.
setCaching(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Set the number of rows that will be fetched on next
setCaching(int) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
setCaching(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 caching = 9;
setCaching(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setCaching(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setCachingIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setCachingIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setCallQueueLen(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Set the call queue length.
setCallQueueLen(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
setCallQueueLen(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
setCallTimeMs(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setCallTimeout(int) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setCallTimeout(int) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
 
setCallTimeout(int) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setCatalogJanitorEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
Switch for the background CatalogJanitor thread.
setCatalogJanitorEnabled(boolean) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
setCatalogJanitorEnabled(boolean) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
setCell(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
setCellIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
setCells(ArrayList<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
This is not thread safe.
setCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setCellScanner(CellScanner) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
Only used to send cells to rpc server, the returned cells should be set by HBaseRpcController.setDone(CellScanner).
setCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Append
 
setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Delete
 
setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Increment
 
setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Mutation
Sets the visibility expression associated with cells in this Mutation.
setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Put
 
setCellVisibility(TCellVisibility) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
setCellVisibility(TCellVisibility) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setCellVisibility(TCellVisibility) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setCellVisibilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
setCellVisibilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setCellVisibilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setChance(float) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
Set the chance that a row is included.
setChar(char) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
setCharset(Charset) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
Specifies the Charset to use to convert the row key to a String.
setCheckExistenceOnly(boolean) - Method in class org.apache.hadoop.hbase.client.Get
 
setCheckHdfs(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setChildrenLatch(int) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called by the ProcedureExecutor on procedure-load to restore the latch state
setCipher(Cipher) - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
setCipher(Cipher) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
 
setCleanerChoreRunning(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable/Disable the cleaner chore
setCleanerChoreRunning(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
setCleanerChoreRunning(RpcController, MasterProtos.SetCleanerChoreRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
setClientAckTime(long) - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
setClose() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Call this when the next invocation of call should close the scanner
setClosedState(HRegion, ServerName, CloseRegionCoordination.CloseRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.CloseRegionCoordination
Called after region is closed to notify all interesting parties / "register" region as finally closed.
setClosedState(HRegion, ServerName, CloseRegionCoordination.CloseRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination
In ZK-based version we do some znodes transitioning.
setClosestRowBefore(boolean) - Method in class org.apache.hadoop.hbase.client.Get
 
setClosing(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Exposed for some very specific unit tests.
setCluster(Cluster) - Method in class org.apache.hadoop.hbase.rest.client.Client
 
setClusterDown() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
Sets the cluster as down by deleting the znode.
setClusterId(FileSystem, Path, ClusterId, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Writes a new unique identifier for this cluster to the "hbase.id" file in the HBase root directory
setClusterId(ZooKeeperWatcher, ClusterId) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Append
 
setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Delete
 
setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Increment
 
setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Mutation
Marks that the clusters with the given clusterIds have consumed the mutation
setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Put
 
setClusterIds(List<String>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
setClusterKey(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Set the clusterKey which is the concatenation of the slave cluster's: hbase.zookeeper.quorum:hbase.zookeeper.property.clientPort:zookeeper.znode.parent
setClusterStatus(ClusterStatus) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
setClusterStatus(ClusterStatus) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
setClusterStatus(ClusterStatus) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Set the current cluster status.
setClusterStatus(ClusterStatus) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
setClusterUp() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
Sets the cluster as up.
setCode(int) - Method in class org.apache.hadoop.hbase.rest.client.Response
 
setColFamTimeRangeMap(Map<ByteBuffer, TTimeRange>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setColFamTimeRangeMapIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
 
setColumn(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes column = 2;
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
name of column
setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
column name
setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
name of column whose value is to be deleted
setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
name of column whose value is to be deleted
setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
column name
setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
column name
setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
column name
setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
setColumnFamilies(List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
list of column family descriptors
setColumnFamiliesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Get
 
setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Query
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp) on a per CF bases.
setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Scan
 
setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
setColumnName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
setColumnName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
setColumnNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
setColumns(List<byte[]>) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
setColumns(List<ColumnSchemaModel>) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
setColumns(int, ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated bytes columns = 3;
setColumns(int, ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
setColumns(int, ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
List of columns to return, null for all columns
setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
List of columns to return, null for all columns
setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
List of columns to return, null for all columns
setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
List of columns to return, null for all columns
setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
columns to scan.
setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
columns to scan.
setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
the columns you want returned
setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
columns to scan.
setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
columns to scan.
setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
setColumns(Map<ByteBuffer, TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setColumns(List<TColumnValue>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
setColumns(List<TColumn>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setColumns(List<TColumn>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setColumns(List<TColumnIncrement>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setColumns(List<TColumn>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setColumnValues(List<TColumnValue>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setColumnValues(List<TColumnValue>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
setColumnValuesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setColumnValuesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Compression types supported in hbase.
setCompactionEnabled(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Setting the table compaction enable flag.
setComparatorClass(Class<? extends KeyValue.KVComparator>) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setCompareOp(TCompareOp) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
comparison to make on the value
setCompareOpIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
setCompression(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
setCompression(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string compression = 5;
setCompression(String) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setCompressionBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string compression = 5;
setCompressionCodec(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
Set compression context for this entry.
setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.wal.WALKey
 
setCompressionIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Compression types supported in hbase.
setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Set whether the tags should be compressed along with DataBlockEncoding.
setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
setConcurrentCallsPerServer(int) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.BaseConfigurable
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Sets the configuration.
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
Sets the configuration.
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
Sets the configuration.
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Sets the configuration.
setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
Inform the policy that some configuration has been change, so cached value should be updated it any.
setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.NoOpHeapMemoryTuner
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionFactory
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
 
setConf(Configuration, ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
 
setConf(Configuration, ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
 
setConf(Configuration, ZooKeeperWatcher, ReplicationQueuesClient) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.UserProvider
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.EnforcingScanLabelGenerator
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.FeedUserAuthScanLabelGenerator
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.tool.CanaryTool
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
 
setConfig(Configuration) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.ImplData
 
setConfiguration(HTableDescriptor, Class<? extends Constraint>, Configuration) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Update the configuration for the Constraint; does not change the order in which the constraint is run.
setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Setter for storing a configuration setting in HColumnDescriptor.configuration map.
setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Setter for storing a configuration setting in HTableDescriptor.configuration map.
setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
Setter for storing a configuration setting in NamespaceDescriptor.configuration map.
setConfigure(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
 
setConflictWaitIterationMs(int) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
 
setConnection(String, int) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
 
setConnection(String, int) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
Registers current handler client details.
setConnector(Connector) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Get
 
setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Query
Sets the consistency level for this operation
setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Scan
 
setContentLength(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
setContext(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Set the metrics context tag
setControllerException(RpcController, IOException) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Stores an exception encountered during RPC invocation so it can be passed back through to the client.
setCoprocessorHost(RegionCoprocessorHost) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
setCorePoolSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
setCorePoolSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
setCount(long) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
required int64 count = 1 [default = 0];
setCounter(String, long) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
setCurBlockCacheSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
setCurBlockCacheUsed(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
setCurMemStoreSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
setCurMemStoreUsed(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
setCurrentBuffer(ByteBuffer) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
setCurrentBuffer(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
Set on which buffer there will be done seeking.
setCurrentBuffer(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
setCurrentCell(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
setCurrentCompactedKVs(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
setCurrentCompactedKVs(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 currentCompactedKVs = 13;
setCursorPosition(int, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
setCursorPosition(int, int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
 
setCursorPosition(int, int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
setCursorPosition(int, int) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
 
setCurTaskZKVersion(MutableInt) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
 
setDaemon(boolean) - Method in class org.apache.hadoop.hbase.util.HasThread
 
setDaemonThreadRunning(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
Utility method that sets name, daemon status and starts passed thread.
setDaemonThreadRunning(Thread, String) - Static method in class org.apache.hadoop.hbase.util.Threads
Utility method that sets name, daemon status and starts passed thread.
setDaemonThreadRunning(Thread, String, Thread.UncaughtExceptionHandler) - Static method in class org.apache.hadoop.hbase.util.Threads
Utility method that sets name, daemon status and starts passed thread.
setData(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes data = 4;
setData(String, byte[], int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
setData is NOT an idempotent operation.
setData(ZooKeeperWatcher, String, byte[], int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Sets the data of the existing znode to be the specified data.
setData(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Sets the data of the existing znode to be the specified data.
setData(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
 
setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Set data block encoding algorithm used in block cache.
setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
setDataIndexCount(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setDeadNodes(List<String>) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
setDeadNodes(int, String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated string deadNodes = 2;
setDeadServers(Set<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
setDeadServers(Set<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
setDefaultClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
setDeleted(long, boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
setDeletedTable(TableName) - Method in interface org.apache.hadoop.hbase.TableStateManager
Mark table as deleted.
setDeletedTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
Deletes the table in zookeeper.
setDeleteFamilyBloomFilterFaulty() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
setDeleteSingle(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
setDeleteType(BulkDeleteProtos.BulkDeleteRequest.DeleteType) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .hbase.pb.BulkDeleteRequest.DeleteType deleteType = 2;
setDeleteType(TDeleteType) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setDeleteTypeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setDepth(int) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
setDescription(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
setDescription(String, String) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
Sets the region/store name, for logging.
setDestination(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionPlan
Set the destination server for the plan for this region.
setDetails(SplitLogManagerCoordination.SplitLogManagerDetails) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Provide the configuration from the SplitLogManager
setDetails(SplitLogManagerCoordination.SplitLogManagerDetails) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
setDFSReplication(short) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Set the replication factor to hfile(s) belonging to this family
setDisplayFullReport() - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
Display the full report from fsck.
setDone(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setDone(CellScanner) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
IMPORTANT: always call this method if the call finished without any exception to tell the HBaseRpcController that we are done.
setDone(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Append
 
setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Delete
 
setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Increment
 
setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Mutation
Set the durability for this mutation
setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Put
 
setDurability(Durability) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Sets the Durability setting for the table.
setDurability(TDurability) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
setDurability(TDurability) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setDurability(TDurability) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setDurability(TDurability) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setDurabilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
setDurabilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setDurabilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setDurabilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setEffectiveUser(String) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
Set the current thread local effective user
setEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
 
setEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
 
setEnabledTable(TableName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
setEncodeOnDisk(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.98 (HBASE-9870). This will be removed in HBase 2.0.0. This method does nothing now.
setEncodingState(EncodingState) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
setEncodingState(EncodingState) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
Sets the encoding state.
setEncryptionContext(Encryption.Context) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Set the raw crypto key attribute for the family
setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setEncryptionType(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Set the encryption algorithm for use with this family
setEndKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
setEndKey(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
 
setEndKey(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional bytes endKey = 3;
setEndKey(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setEndKey(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setEndKey(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setEndKey(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setEndKeyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setEndKeyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
setEndRow(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bytes endRow = 2;
setEndTime(long) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
setEndTime(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int64 endTime = 6;
setEndTime(long) - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
setEntries(List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
 
setEntryCount(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setErr(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
 
setErrorHandler(HBaseRPCErrorHandler) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
Set the handler for calling out of RPC for error conditions.
setErrorHandler(HBaseRPCErrorHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
 
setEventLoopConfig(Configuration, EventLoopGroup, Class<? extends Channel>) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
Set the EventLoopGroup and channel class for AsyncRpcClient.
setEventReady(MasterProcedureScheduler.ProcedureEvent, boolean) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setEvictCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
setEvictOnClose(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Only used for testing.
setExist(AlreadyExists) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
setExistIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
setExists(Boolean) - Method in class org.apache.hadoop.hbase.client.Result
 
setExpectedVersion(int) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
 
setExpiration(long) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
 
setExpression(String) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
setExpressionIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setFailed(IOException) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setFailed(IOException) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
Set failed with an exception to pass on.
setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setFailed(IOException) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
setFailedOn(IOException) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
Sets an exception to be communicated back to the Service client.
setFailure(String, Throwable) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
setFailure(RemoteProcedureException) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
setFailureResultForNonce(NonceKey, String, User, IOException) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
If the failure failed before submitting it, we may want to give back the same error to the requests with the same nonceKey.
setFamilies(Map<byte[], ? extends Collection<?>>) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
 
setFamily(byte[]) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
 
setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
column name
setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
column family to check
setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
column family to check
setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
column family to check
setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Append
 
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Delete
 
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Increment
 
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Mutation
Method for setting the put's familyMap
setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Put
 
setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Append
Deprecated.
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Increment
Deprecated.
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
setFamilyMap(Map<byte[], NavigableSet<byte[]>>) - Method in class org.apache.hadoop.hbase.client.Scan
Setting the familyMap
setFamilyOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setFanIndex(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
setFieldValue(AlreadyExists._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
setFieldValue(BatchMutation._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
setFieldValue(ColumnDescriptor._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setFieldValue(Hbase.append_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
setFieldValue(Hbase.append_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
setFieldValue(Hbase.atomicIncrement_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
setFieldValue(Hbase.atomicIncrement_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
setFieldValue(Hbase.checkAndPut_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
setFieldValue(Hbase.checkAndPut_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
setFieldValue(Hbase.compact_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
setFieldValue(Hbase.compact_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
setFieldValue(Hbase.createTable_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
setFieldValue(Hbase.createTable_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
setFieldValue(Hbase.deleteAll_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
setFieldValue(Hbase.deleteAll_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
setFieldValue(Hbase.deleteAllRow_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
setFieldValue(Hbase.deleteAllRow_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
setFieldValue(Hbase.deleteAllRowTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
setFieldValue(Hbase.deleteAllRowTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
setFieldValue(Hbase.deleteAllTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
setFieldValue(Hbase.deleteAllTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
setFieldValue(Hbase.deleteTable_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
setFieldValue(Hbase.deleteTable_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
setFieldValue(Hbase.disableTable_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
setFieldValue(Hbase.disableTable_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
setFieldValue(Hbase.enableTable_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
setFieldValue(Hbase.enableTable_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
setFieldValue(Hbase.get_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
setFieldValue(Hbase.get_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
setFieldValue(Hbase.getColumnDescriptors_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
setFieldValue(Hbase.getColumnDescriptors_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
setFieldValue(Hbase.getRegionInfo_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
setFieldValue(Hbase.getRegionInfo_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
setFieldValue(Hbase.getRow_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
setFieldValue(Hbase.getRow_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
setFieldValue(Hbase.getRowOrBefore_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
setFieldValue(Hbase.getRowOrBefore_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
setFieldValue(Hbase.getRows_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
setFieldValue(Hbase.getRows_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
setFieldValue(Hbase.getRowsTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
setFieldValue(Hbase.getRowsTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
setFieldValue(Hbase.getRowsWithColumns_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
setFieldValue(Hbase.getRowsWithColumns_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
setFieldValue(Hbase.getRowsWithColumnsTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
setFieldValue(Hbase.getRowsWithColumnsTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
setFieldValue(Hbase.getRowTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
setFieldValue(Hbase.getRowTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
setFieldValue(Hbase.getRowWithColumns_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
setFieldValue(Hbase.getRowWithColumns_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
setFieldValue(Hbase.getRowWithColumnsTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
setFieldValue(Hbase.getRowWithColumnsTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
setFieldValue(Hbase.getTableNames_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
setFieldValue(Hbase.getTableNames_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
setFieldValue(Hbase.getTableRegions_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
setFieldValue(Hbase.getTableRegions_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
setFieldValue(Hbase.getVer_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
setFieldValue(Hbase.getVer_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
setFieldValue(Hbase.getVerTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
setFieldValue(Hbase.getVerTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
setFieldValue(Hbase.increment_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
setFieldValue(Hbase.increment_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
setFieldValue(Hbase.incrementRows_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
setFieldValue(Hbase.incrementRows_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
setFieldValue(Hbase.isTableEnabled_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
setFieldValue(Hbase.isTableEnabled_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
setFieldValue(Hbase.majorCompact_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
setFieldValue(Hbase.majorCompact_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
setFieldValue(Hbase.mutateRow_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
setFieldValue(Hbase.mutateRow_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
setFieldValue(Hbase.mutateRows_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
setFieldValue(Hbase.mutateRows_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
setFieldValue(Hbase.mutateRowsTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
setFieldValue(Hbase.mutateRowsTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
setFieldValue(Hbase.mutateRowTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
setFieldValue(Hbase.mutateRowTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
setFieldValue(Hbase.scannerClose_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
setFieldValue(Hbase.scannerClose_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
setFieldValue(Hbase.scannerGet_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
setFieldValue(Hbase.scannerGet_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
setFieldValue(Hbase.scannerGetList_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
setFieldValue(Hbase.scannerGetList_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
setFieldValue(Hbase.scannerOpen_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
setFieldValue(Hbase.scannerOpen_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
setFieldValue(Hbase.scannerOpenTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
setFieldValue(Hbase.scannerOpenTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
setFieldValue(Hbase.scannerOpenWithPrefix_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
setFieldValue(Hbase.scannerOpenWithPrefix_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
setFieldValue(Hbase.scannerOpenWithScan_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
setFieldValue(Hbase.scannerOpenWithScan_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
setFieldValue(Hbase.scannerOpenWithStop_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
setFieldValue(Hbase.scannerOpenWithStop_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
setFieldValue(Hbase.scannerOpenWithStopTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
setFieldValue(Hbase.scannerOpenWithStopTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
setFieldValue(IllegalArgument._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
setFieldValue(IOError._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
setFieldValue(Mutation._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
setFieldValue(TAppend._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
setFieldValue(TCell._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
setFieldValue(TColumn._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
setFieldValue(TIncrement._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
setFieldValue(TRegionInfo._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setFieldValue(TRowResult._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
setFieldValue(TScan._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setFieldValue(TAppend._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
setFieldValue(TAuthorization._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
setFieldValue(TCellVisibility._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
setFieldValue(TColumn._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
setFieldValue(TColumnIncrement._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
setFieldValue(TColumnValue._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setFieldValue(TDelete._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setFieldValue(TGet._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setFieldValue(THBaseService.append_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
setFieldValue(THBaseService.append_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
setFieldValue(THBaseService.checkAndDelete_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
setFieldValue(THBaseService.checkAndDelete_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
setFieldValue(THBaseService.checkAndMutate_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
setFieldValue(THBaseService.checkAndMutate_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
setFieldValue(THBaseService.checkAndPut_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setFieldValue(THBaseService.checkAndPut_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
setFieldValue(THBaseService.closeScanner_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
setFieldValue(THBaseService.closeScanner_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
setFieldValue(THBaseService.deleteMultiple_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
setFieldValue(THBaseService.deleteMultiple_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
setFieldValue(THBaseService.deleteSingle_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
setFieldValue(THBaseService.deleteSingle_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
setFieldValue(THBaseService.exists_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
setFieldValue(THBaseService.exists_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
setFieldValue(THBaseService.existsAll_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
setFieldValue(THBaseService.existsAll_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
setFieldValue(THBaseService.get_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
setFieldValue(THBaseService.get_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
setFieldValue(THBaseService.getAllRegionLocations_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
setFieldValue(THBaseService.getAllRegionLocations_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
setFieldValue(THBaseService.getMultiple_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
setFieldValue(THBaseService.getMultiple_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
setFieldValue(THBaseService.getRegionLocation_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
setFieldValue(THBaseService.getRegionLocation_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
setFieldValue(THBaseService.getScannerResults_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
setFieldValue(THBaseService.getScannerResults_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
setFieldValue(THBaseService.getScannerRows_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
setFieldValue(THBaseService.getScannerRows_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
setFieldValue(THBaseService.increment_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
setFieldValue(THBaseService.increment_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
setFieldValue(THBaseService.mutateRow_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
setFieldValue(THBaseService.mutateRow_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
setFieldValue(THBaseService.openScanner_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
setFieldValue(THBaseService.openScanner_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
setFieldValue(THBaseService.put_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
setFieldValue(THBaseService.put_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
setFieldValue(THBaseService.putMultiple_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
setFieldValue(THBaseService.putMultiple_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
setFieldValue(THRegionInfo._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setFieldValue(THRegionLocation._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
setFieldValue(TIllegalArgument._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
setFieldValue(TIncrement._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setFieldValue(TIOError._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
setFieldValue(TPut._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setFieldValue(TResult._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
setFieldValue(TRowMutations._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
setFieldValue(TScan._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setFieldValue(TServerName._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
setFieldValue(TTimeRange._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
setFileCreateTime(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
setFileInfoOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setFilename(String) - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
 
setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Get
 
setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Query
Apply the specified server-side filter when performing the Query.
setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Scan
 
setFilter(String) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
setFilter(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional string filter = 8;
setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
 
setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
setFilterBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional string filter = 8;
setFilterIfMissing(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Set whether entire row should be filtered if column is not found.
setFilterString(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setFilterString(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setFilterString(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setFilterString(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setFilterString(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setFilterString(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setFilterStringIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setFilterStringIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setFilterStringIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setFindPort(boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
setFirst(T1) - Method in class org.apache.hadoop.hbase.util.Pair
Replace the first element of the pair.
setFirst(A) - Method in class org.apache.hadoop.hbase.util.Triple
 
setFirstDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setFirstInsertionIndex(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setFirstRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
 
setFirstRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
 
setFirstRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
In HBase, the last row is represented by an empty byte array.
setFirstRow(byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
Set the first row
setFirstRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
setFirstRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
setFixAssignments(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Fix inconsistencies found by fsck.
setFixEmptyMetaCells(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFixHdfsHoles(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFixHdfsOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFixHdfsOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFixHFileLinks(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFixMeta(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFixReferenceFiles(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFixReplication(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Set replication fix mode.
setFixSplitParents(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFixTableLocks(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Set table locks fix mode.
setFixTableOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFixTableZNodes(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Set orphaned table ZNodes fix mode.
setFixVersionFile(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFlushPolicyClassName(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
This sets the class associated with the flush policy which determines determines the stores need to be flushed when flushing a region.
setForceExclusive() - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
Set exclusive mode.
setForegroundColor(Color) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
 
setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
setFoundKV(boolean) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
setFrags(Map<String, Integer>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
setFrags(Map<String, Integer>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
setFsDefault(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
setGauge(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Set a gauge to a specific value.
setGauge(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
Set a single gauge to a value.
setGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
setGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
setGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
setGeneralBloomFilterFaulty() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
setGlobalMemstoreLimit(long) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
Sets the global memstore limit to a new size.
setHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
setHeaders(Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
 
setHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
setHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int32 heapSizeMB = 4;
setHFileCorruptionChecker(HFileCorruptionChecker) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setHostName(String) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
setHostNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
setHTable(Table) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
setHTable(Table) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
setHTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Deprecated.
Use setTable() instead.
setHTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Sets the HBase table.
setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
setIa(TIllegalArgument) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
if the scannerId is invalid
setIa(TIllegalArgument) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
if the scannerId is invalid
setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
setId(String) - Method in class org.apache.hadoop.hbase.client.Append
 
setId(String) - Method in class org.apache.hadoop.hbase.client.Delete
 
setId(String) - Method in class org.apache.hadoop.hbase.client.Get
 
setId(String) - Method in class org.apache.hadoop.hbase.client.Increment
 
setId(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
This method allows you to set an identifier on an operation.
setId(String) - Method in class org.apache.hadoop.hbase.client.Put
 
setId(String) - Method in class org.apache.hadoop.hbase.client.Scan
 
setId(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setId(long) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
 
setId(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional int64 id = 4;
setId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
id of a scanner returned by scannerOpen
setId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
id of a scanner returned by scannerOpen
setId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
id of a scanner returned by scannerOpen
setId(long) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
setIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
setIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
setIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setIgnoreDeleteForTesting(boolean) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
Temporary function that is used by unit tests only
setIgnorePreCheckPermission(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setIncludesMvcc(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
setIncludesMvccVersion(byte) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setIncludesMvccVersion(boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setIncludesTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
setIncrement(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
The single increment to apply
setIncrementIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
setIncrements(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
The list of increments
setIncrementsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
setInfoFamilyCachingForMeta(HTableDescriptor, boolean) - Static method in class org.apache.hadoop.hbase.master.MasterFileSystem
Enable in memory caching for hbase:meta
setInfoPort(int) - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
 
setInitialized(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
setInitLatch(CountDownLatch) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional bool inMemory = 4;
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setInMemoryIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setInput(Configuration, Map<String, Collection<Scan>>, Path) - Static method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
Configure conf to read from snapshotScans, with snapshots restored to a subdirectory of restoreDir.
setInput(JobConf, String, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
setInput(JobConf, String, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
setInput(Configuration, Map<String, Collection<Scan>>, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
 
setInput(Configuration, Map<String, Collection<Scan>>, Path) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
Configure conf to read from snapshotScans, with snapshots restored to a subdirectory of restoreDir.
setInput(Job, String, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
setInput(Job, String, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
setInput(Configuration, String, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
setInput(Configuration, String, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
 
setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
setInsertionIndexes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setIntHeader(String, int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
setIsDelete(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
setIsDeleteIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
setIsMajor(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
Specify if this compaction should be a major compaction based on the state of the store
setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Get
 
setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Query
Set the isolation level for this query.
setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Scan
 
setIv(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
 
setIv(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
 
setIv(byte[]) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
Set the initialization vector
setIv(byte[]) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Set the initialization vector
setJerseyVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
 
setJerseyVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jerseyVersion = 5;
setJerseyVersionBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jerseyVersion = 5;
setJVMVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
 
setJvmVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jvmVersion = 2;
setJvmVersionBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jvmVersion = 2;
setKeepDeletedCells(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-12363). This will be removed in HBase 2.0.0. Use HColumnDescriptor.setKeepDeletedCells(KeepDeletedCells).
setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setKeepDeletes(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
setKeepProgress(boolean) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
 
setKerberosNameRulesKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
 
setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
 
setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
setKey(Key) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
Set the secret key
setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
 
setKey(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
 
setKey(Key) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Set the secret key
setKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
setKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
A setter that helps to avoid object creation every time and whenever there is a need to create new KeyOnlyKeyValue.
setKey(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
 
setKey(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
required bytes key = 1;
setKey(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
required string key = 1;
setKeyBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
required string key = 1;
setKeytabConfKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
setKeyValues(Configuration, String, Collection<Map.Entry<String, String>>) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
Store a collection of Map.Entry's in conf, with each entry separated by ',' and key values delimited by ConfigurationUtil.KVP_DELIMITER
setKeyValues(Configuration, String, Collection<Map.Entry<String, String>>, char) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
Store a collection of Map.Entry's in conf, with each entry separated by ',' and key values delimited by delimiter.
setLabels(int, String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
repeated string labels = 10;
setLabels(List<String>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
setLabelsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
setLastAppliedOpAge(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
 
setLastAppliedOpAge(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
 
setLastContact(long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
setLastDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setLastPeekedCell(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
 
setLastQuery(long) - Method in class org.apache.hadoop.hbase.quotas.QuotaState
 
setLastRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
 
setLastRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
 
setLastRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
In HBase, the last row is represented by an empty byte array.
setLastRow(byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
Set the last row
setLastRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
setLastRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
setLastShippedAge(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
setLastShippedAge(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
setLastShippedAge(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Set whether only the latest version of the column value should be compared.
setLength(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
setLength(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
Update the length of this range.
setLength(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Update the length of this range.
setLength(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
setLength(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
Update the length of this range.
setLimit(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set the limit of rows for this scan.
setLimit(int) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
 
setLimit(int) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
 
setLimit(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
setLimit(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Limits the byte range upto a specified value.
setLimit(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
setListener(EventHandler.EventHandlerListener) - Method in class org.apache.hadoop.hbase.executor.EventHandler
 
setLiveNodes(List<StorageClusterStatusModel.Node>) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
setLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
setLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Get
 
setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Query
Set the value indicating whether loading CFs on demand should be allowed (cluster default is false).
setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
 
setLoadOnOpenOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setLocation(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
setLocation(String) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
 
setLocation(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional string location = 5;
setLocationBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional string location = 5;
setLocations(Path, Path...) - Method in class org.apache.hadoop.hbase.io.FileLink
NOTE: This method must be used only in the constructor! It creates a List with the specified locations for the link.
setLogDir(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
setLoggingUncaughtExceptionHandler(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
Sets an UncaughtExceptionHandler for the thread which logs the Exception stack if the thread dies.
setLogPosition(String, String, long) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
Set the current position for a specific WAL in a given queue.
setLogPosition(String, String, long) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
 
setLogRecoveryMode() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
The function is used in SSH to set recovery mode based on configuration after all outstanding log split tasks drained.
setMajorRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
Sets compaction "major range".
setMapperClass(Job, Class<? extends Mapper<ImmutableBytesWritable, Result, K2, V2>>) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
Set the application's mapper class.
setMaster(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl.ImplData
 
setMaster(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
setMaster(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
 
setMasterAddress(ZooKeeperWatcher, String, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Set master address into the master znode or into the backup subdirectory of backup masters; switch off the passed in znode path.
setMasterRpcServices(MasterRpcServices) - Method in interface org.apache.hadoop.hbase.master.normalizer.RegionNormalizer
Set the master RPC service.
setMasterRpcServices(MasterRpcServices) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
 
setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
setMasterServices(MasterServices) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Set the master service.
setMasterServices(MasterServices) - Method in interface org.apache.hadoop.hbase.master.normalizer.RegionNormalizer
Set the master service.
setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
Set the master service.
setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
setMaxAttempts(int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
 
setMaxChunkSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
 
setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Sets the maximum size upto which a region can grow to after which a region split is triggered.
setMaxHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
setMaxHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int32 maxHeapSizeMB = 5;
setMaxMemstoreTS(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
setMaxMerge(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setMaxOverlapsToSideline(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setMaxPoolSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
setMaxPoolSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
setMaxProcId(long) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureLoader
Called by ProcedureStore.load() to notify about the maximum proc-id in the store.
setMaxQualifierLength(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setMaxQueueSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
setMaxQueueSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
setMaxResultSize(long) - Method in class org.apache.hadoop.hbase.client.Scan
Set the maximum result size.
setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
Set the maximum number of values to return per row per Column Family
setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set the maximum number of values to return per row per Column Family
setMaxRowLength(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
setMaxSize(long) - Method in interface org.apache.hadoop.hbase.io.hfile.ResizableBlockCache
Sets the max heap size that can be used by the BlockCache.
setMaxSleepTime(long) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
 
setMaxStamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
setMaxStampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
setMaxTagsLength(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setMaxThroughput(double) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
setMaxValues(int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
Get all available versions.
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Get
Get up to the specified number of versions of each column.
setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
Get all available versions.
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Scan
Get up to the specified number of versions of each column.
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional int32 maxVersions = 4;
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 maxVersions = 7;
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setMaxVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setMaxVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setMaxVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Represents the maximum size of the memstore after which the contents of the memstore are flushed to the filesystem.
setMemstoreSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
 
setMemstoreSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
setMemstoreSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 memstoreSizeMB = 5;
setMerged(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
setMetaIndexCount(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setMetaLocation(ServerName) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
setMetaLocation(ServerName) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
setMetaLocation(ZooKeeperWatcher, ServerName, RegionState.State) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Sets the location of hbase:meta in ZooKeeper to the specified server address.
setMetaLocation(ZooKeeperWatcher, ServerName, int, RegionState.State) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Sets the location of hbase:meta in ZooKeeper to the specified server address.
setMetaRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used to denote if the current table represents -ROOT- or hbase:meta region.
setMetricsSource(JvmPauseMonitorSource) - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
 
setMinFilesToCompact(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
Set upper bound on number of files to be included in minor compactions
setMinIndexNumEntries(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
 
setMinMvccVersion(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setMinStamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
setMinStampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
setMinThreshold(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
Overwrite min threshold for compaction
setMinTimestamp(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setMinVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setMput(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
mutation for the put
setMputIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
setMServerWrap(MetricsHBaseServerWrapper) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.ImplData
 
setMutations(List<Mutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
setMutations(List<Mutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
list of mutation commands
setMutations(List<Mutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
list of mutation commands
setMutations(List<TMutation>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
setMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
setMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
setMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
setMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
setMvccReadPoint(Scan, long) - Static method in class org.apache.hadoop.hbase.client.PackagePrivateFieldAccessor
 
setMvccVersionDeltaWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setMvccVersionFields(LongEncoder) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setMvccVersionIndexWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setMWrap(MetricsRegionServerWrapper) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.ImplData
 
setName(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
setName(TableName) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
setName(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
Deprecated.
setName(String) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
setName(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
setName(String) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
 
setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableModel
 
setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
 
setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string name = 1;
setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string name = 1;
setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
required string name = 1;
setName(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
required bytes name = 1;
setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
required string name = 1;
setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
required string name = 1;
setName(int, String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
repeated string name = 1;
setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string name = 1;
setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional string name = 1;
setName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setName(String) - Method in class org.apache.hadoop.hbase.util.HasThread
 
setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string name = 1;
setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string name = 1;
setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
required string name = 1;
setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
required string name = 1;
setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
required string name = 1;
setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string name = 1;
setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional string name = 1;
setNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setNamespace(int, String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces.Builder
repeated string namespace = 1;
setNamespace(String) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
 
setNamespaceFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Set the namespace filter regex
setNamespaceGroupPermissions(String, String, List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Overwrites the existing permission set for a group and triggers an update for zookeeper synchronization.
setNamespaceQuota(MasterProcedureEnv, NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
Set quota for the namespace
setNamespaceQuota(String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
setNamespaceQuota(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
setNamespaces(List<String>) - Method in class org.apache.hadoop.hbase.rest.model.NamespacesModel
 
setNamespaceUserPermissions(String, String, List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Overwrites the existing permission set for a given user for a table, and triggers an update for zookeeper synchronization.
setNbRows(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
number of results to return
setNbRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
setNeedCursorResult(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
When the server is slow or we scan a table with many deleted data or we use a sparse filter, the server will response heartbeat to prevent timeout.
setNegativeIndex(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setNewStartKey() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Will be called in moveToNextRegion when currentRegion is null.
setNewStartKey() - Method in class org.apache.hadoop.hbase.client.ClientSimpleScanner
 
setNewStartKey() - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
 
setNextNodeOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNextPtr(LruHashMap.Entry<K, V>) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Sets the next pointer for the entry in the LRU.
setNextRefillTime(long) - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
 
setNextRefillTime(long) - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
 
setNextRefillTime(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
 
setNextState(MasterProcedureProtos.AddColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
setNextState(MasterProcedureProtos.CreateNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
setNextState(MasterProcedureProtos.CreateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
setNextState(MasterProcedureProtos.DeleteColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
setNextState(MasterProcedureProtos.DeleteNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
setNextState(MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
setNextState(MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
setNextState(MasterProcedureProtos.ModifyColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
setNextState(MasterProcedureProtos.ModifyNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
setNextState(MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
setNextState(TState) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
Set the next state for the procedure.
setNodeFirstInsertionIndexes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
write
setNonce(long) - Method in class org.apache.hadoop.hbase.client.Action
 
setNonceGroup(long) - Method in class org.apache.hadoop.hbase.client.MultiAction
 
setNonceKey(NonceKey) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called by the ProcedureExecutor to set the value to the newly created procedure.
setNonSeekedState() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
setNonSeekedState() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
 
setNormalizationEnabled(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Setting the table normalization enable flag.
setNormalizerOn(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.RegionNormalizerTracker
Set region normalizer on/off
setNormalizerRunning(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Turn region normalizer on or off.
setNormalizerRunning(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Turn region normalizer on or off.
setNormalizerRunning(RpcController, MasterProtos.SetNormalizerRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
setNoStripeMetadata() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
setNumberOfThreads(Job, int) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
Set the number of threads in the pool for running maps.
setNumDataIndexLevels(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setNumFamilyBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNumKeyValueBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNumMapTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets the number of map tasks for the given job configuration to the number of regions the given table has.
setNumMetaBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNumMovedRegions(int) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
 
setNumMvccVersionBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNumOccurrences(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setNumQualifierBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNumReduceTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets the number of reduce tasks for the given job configuration to the number of regions the given table has.
setNumReduceTasks(String, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets the number of reduce tasks for the given job configuration to the number of regions the given table has.
setNumRegions(int) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
 
setNumRowBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNumRows(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
number of rows to return
setNumRows(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
number of rows to return
setNumRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
setNumRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
setNumTagsBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNumTimestampBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNumUniqueFamilies(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNumUniqueQualifiers(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNumUniqueRows(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNumUniqueTags(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNumValueBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setNumVersions(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
number of versions to retrieve
setNumVersions(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
number of versions to retrieve
setNumVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
setNumVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
setOffline(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
The parent of a region split is offline while split daughters hold references to the parent.
setOffline(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setOfflineIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setOffPeak(boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
setOffset(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
setOffset(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
Update the beginning of this range.
setOffset(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Update the beginning of this range.
setOffset(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
setOffset(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
Update the beginning of this range.
setOneRowLimit() - Method in class org.apache.hadoop.hbase.client.Scan
Call this when you only want to get one row.
setOnlineRegions(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
 
setOperationStatus(int, OperationStatus) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
Sets the status code for the operation(Mutation) at the specified position.
setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
 
setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
setOperationTimeout(int) - Method in interface org.apache.hadoop.hbase.client.Table
Set timeout (millisecond) of each operation in this Table instance, will override the value of hbase.client.operation.timeout in configuration.
setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
setOrigLogSeqNum(long) - Method in class org.apache.hadoop.hbase.wal.WALKey
Used to set original seq Id for WALKey during wal replay
setOSVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
 
setOsVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string osVersion = 3;
setOsVersionBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string osVersion = 3;
setOutputArrayOffset(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setOwner(User) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
since 0.94.1
setOwner(String) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
setOwnerString(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
since 0.94.1
setParent(TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setParentProcId(long) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called by the ProcedureExecutor to assign the parent to the newly created procedure.
setParentStartPosition(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
get/set
setPartialFlag(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
setPathSpec(String[]) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
setPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
setPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Set the replicable table-cf config of the specified peer
setPeerTableCFsConfig(String, Map<TableName, ? extends Collection<String>>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Set the table and column-family list of the peer to ZK.
setPeerTableCFsConfig(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
setPendingShipment(boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
 
setPolicy(HttpConfig.Policy) - Method in class org.apache.hadoop.hbase.http.HttpConfig
 
setPort(int) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
Deprecated.
setPort(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setPort(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
setPortIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setPortIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
setPosition(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
setPosition(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
Update the position index.
setPosition(long) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
 
setPrefetchBlocksOnOpen(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setPrevPtr(LruHashMap.Entry<K, V>) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Sets the previous pointer for the entry in the LRU.
setPrimaryReplicaReader(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
setPrimaryReplicaReader(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
setPrintStreams(PrintStream, PrintStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.Append
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.Delete
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.Get
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.Increment
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
setPriority(int) - Method in class org.apache.hadoop.hbase.client.Scan
 
setPriority(int) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
setPriority(int) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
 
setPriority(TableName) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
 
setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
setPriority(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
Sets the priority for the request
setPriority(int) - Method in class org.apache.hadoop.hbase.util.HasThread
 
setProcId(long) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
 
setProcId(long) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called by the ProcedureExecutor to assign the ID to the newly created procedure.
setProcIds(long, long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
setProps(int, NamespacePropertiesMessage.NamespaceProperties.Property) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
setProps(int, NamespacePropertiesMessage.NamespaceProperties.Property.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.NamespaceProperties.Property props = 1;
setPublishStatusInZk(boolean) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
 
setPut(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
 
setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
column qualifier to check
setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
column qualifier to check
setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
column qualifier to check
setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setQualifierOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setQuota(QuotaSettings) - Method in interface org.apache.hadoop.hbase.client.Admin
Apply the new quota settings.
setQuota(QuotaSettings) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Apply the new quota settings.
setQuota(RpcController, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
setQuota(MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
setQuotas(QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.QuotaState
Setup the global quota information.
setQuotas(QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
 
setQuotas(TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
Add the quota information of the specified table.
setQuotas(String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
Add the quota information of the specified namespace.
setRackManager(RackManager) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
setRandomGeneratorForTest(Random) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
Sets a random generator to be used for look-ups instead of computing hashes.
setRaw(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Enable/disable "raw" mode for this scan.
setReaderRunning(boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReaderThread
 
setReadLatency(long) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Setting the table as read only sets all the columns in the table as read only.
setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional bool readOnly = 5;
setReadRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
setReadRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 readRequestsCount = 7;
setReadRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
 
setReadRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
setReadRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.Table
Set timeout (millisecond) of each rpc read request in operations of this Table instance, will override the value of hbase.rpc.read.timeout in configuration.
setReadRpcTimeout(int) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
setReadsEnabled(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
setReadSuccess() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
setReadType(Scan.ReadType) - Method in class org.apache.hadoop.hbase.client.Scan
Set the read type for this scan.
setReason(String) - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
setRecovering(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Reset recovering state of current region
setRecoveryMode(boolean) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Change the recovery mode.
setRecoveryMode(boolean) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
This function is to set recovery mode from outstanding split log tasks from before or current configuration setting
setRecoveryMode(boolean) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
This function is to set recovery mode from outstanding split log tasks from before or current configuration setting
setRegionCachePrefetch(TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
does nothing since since 0.99
setRegionCachePrefetch(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
does nothing since 0.99
setRegionCachePrefetch(byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
does nothing since 0.99
setRegionCachePrefetch(TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
does nothing since 0.99
setRegionCachePrefetch(Configuration, byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
does nothing since 0.99
setRegionCachePrefetch(Configuration, TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
does nothing since 0.99
setRegionCoprocessorHost(RegionCoprocessorHost) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Sets the region coprocessor env.
setRegionFilter(String) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
sets the region by which output will be filtered
setRegionId(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setRegionIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setRegionInfo(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.normalizer.SplitNormalizationPlan
 
setRegionInfo(THRegionInfo) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
setRegionInfoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
setRegionMemstoreReplication(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Enable or Disable the memstore replication from the primary region to the replicas.
setRegionReplication(int) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Sets the number of replicas per region.
setRegions(List<StorageClusterStatusModel.Node.Region>) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
setRegions(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
setRegions(List<TableRegionModel>) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
 
setRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional int32 regions = 3;
setRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
setRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
setRegions(int, TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
setRegions(int, TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
setRegionServer(HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
 
setRegionServer(HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
 
setRegionServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
Set the list of region servers for that peer
setRegionSplitPolicyClassName(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
This sets the class associated with the region split policy which determines when a region split should occur.
setRegionStateTOCLOSED(byte[], ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
Set the region state to CLOSED
setRegionStateTOCLOSED(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
Set the region state to CLOSED
setRegionsToReopen(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Set the list of regions that will be reopened because of an update in table schema
setReload(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
setReloadIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
setRemoveParents(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setRenew(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Indicate whether we make a call only to renew the lease, but without affected the scanner in any other way.
setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Get
 
setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Query
Specify region replica id where Query will fetch data from.
setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Scan
 
setReplicaId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setReplicaIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setReplicaStoreFile(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
setReplicationEndpointImpl(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Sets the ReplicationEndpoint plugin class for this peer.
setRequest(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
 
setRequests(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
setRequests(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
setRequests(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional int64 requests = 4;
setRequests(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int64 requests = 3;
setRequestSizeBytes(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setResponse(Object, CellScanner, Throwable, String) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
setResponseSizeBytes(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setRESTVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
 
setRestVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string restVersion = 1;
setRestVersionBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string restVersion = 1;
setResult(byte[]) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
The procedure may leave a "result" on completion.
setRetainDays(int) - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
 
setRetCode(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Append
 
setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Increment
 
setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
 
setReverse(boolean) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
setReversed(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Set whether this scan is a reversed one
setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.Filter
alter the reversed scan flag
setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
setReversed(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setReversed(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setReversedIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setReversedIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setRIT(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
Set the number of regions in transition.
setRIT(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
 
setRITCountOverThreshold(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
Set the count of the number of regions that have been in transition over the threshold time.
setRITCountOverThreshold(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
 
setRITOldestAge(long) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
Set the oldest region in transition.
setRITOldestAge(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
 
setRootDir(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
setRootIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
setRootIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 rootIndexSizeKB = 9;
setRootRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used to denote if the current table represents -ROOT- region.
setRow(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes row = 1;
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
row to increment
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
row key
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
Row to update
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
key of the row to be completely deleted.
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
key of the row to be completely deleted.
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
Row to update
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
row key
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
row key
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
row key
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
row key
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
row key
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
row key
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
row key
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
row key
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
row key
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
row key
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
row key
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
row to check
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
row to check
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
row to check
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
setRowBatches(List<BatchMutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
list of row batches
setRowBatches(List<BatchMutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
list of row batches
setRowBatchesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
setRowBatchesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
setRowBatchSize(int) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required uint32 rowBatchSize = 4;
setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to set the Filter to be used.
setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
setRowFilter(String) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
sets the region by which output will be filtered
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
setRowMutations(TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
row mutations to execute if the value matches
setRowMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
Set offset for the row per Column Family.
setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set offset for the row per Column Family.
setRowPrefixFilter(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Set a filter (using stopRow and startRow) so the result set only contains rows where the rowKey starts with the specified prefix.
setRows(int, CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
setRows(int, CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
setRows(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
row keys
setRows(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
row keys
setRows(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
row keys
setRows(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
row keys
setRowsDeleted(long) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
required uint64 rowsDeleted = 1;
setRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
setRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
setRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
setRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
setRowTreeDepth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setRPC(String, Object[], long) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
 
setRPC(String, Object[], long) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
Tells this instance that it is monitoring a new RPC call.
setRPCPacket(Message) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
 
setRPCPacket(Message) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
Gives this instance a reference to the protobuf received by the RPC, so that it can later compute its size if asked for it.
setRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
setRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
setRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
Deprecated.
setRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Use setReadRpcTimeout or setWriteRpcTimeout instead
setRpcTimeout(int) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
Deprecated.
setRsRpcServices(RSRpcServices) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
setRsRpcServices(RSRpcServices) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
 
setRunner(Runnable) - Method in class org.apache.hadoop.hbase.client.DelayingRunner
 
setRunning(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
Change the state to 'isRunning', returns true if the store state was changed, false if the store was already in that state.
setSaslTokenResponse(ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
setScan(ClientProtos.Scan) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .hbase.pb.Scan scan = 1;
setScan(ClientProtos.Scan.Builder) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .hbase.pb.Scan scan = 1;
setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Sets the scan defining the actual details like columns etc.
setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Sets the scan defining the actual details like columns etc.
setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Sets the scan defining the actual details like columns etc.
setScan(TScan) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
Scan instance
setScanIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
setScanMetricsEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Enable collection of ScanMetrics.
setScannerCaching(int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
setScannerCaching(JobConf, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets the number of rows to return and cache with each scanner iteration.
setScannerCaching(Job, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets the number of rows to return and cache with each scanner iteration.
setScannerId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
the Id of the Scanner to close *
setScannerId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
the Id of the Scanner to return rows from.
setScannerIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
setScannerIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
setScans(List<Scan>) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Allows subclasses to set the list of Scan objects.
setScope(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setScopes(NavigableMap<byte[], Integer>) - Method in class org.apache.hadoop.hbase.wal.WALKey
 
setSecond(T2) - Method in class org.apache.hadoop.hbase.util.Pair
Replace the second element of the pair.
setSecond(B) - Method in class org.apache.hadoop.hbase.util.Triple
 
setSecretManager(SecretManager<? extends TokenIdentifier>) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
setSecurityEnabled(boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
setSequenceFilter(long) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
sets the region by which output will be filtered
setSequenceId(Cell, long) - Static method in class org.apache.hadoop.hbase.CellUtil
Sets the given seqId to the cell.
setSequenceId(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
setSequenceId(long) - Method in class org.apache.hadoop.hbase.KeyValue
 
setSequenceID(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
setSequenceId(long) - Method in interface org.apache.hadoop.hbase.SettableSequenceId
Sets with the given seqId.
setSequenceId(long) - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
setServerCrashProcessingEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
setServerManager(ServerManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
setServerManager(ServerManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
setServerName(ServerName) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination.OpenRegionDetails
Sets server name on which opening operation is running.
setServerName(ServerName) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
 
setServerName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setServerName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setServerName(TServerName) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
setServerNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setServerNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
 
setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
 
setServerSideHConnectionRetries(Configuration, String, Log) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Deprecated.
Internal method, do not use.
setServerSideHConnectionRetriesConfig(Configuration, String, Log) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Changes the configuration to set the number of retries needed when using HConnection internally, e.g.
setServerVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
 
setServerVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string serverVersion = 4;
setServerVersionBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string serverVersion = 4;
setSidelineBigOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setSidelineDir(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setSignatureSecretFileKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
setSize(int) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
 
setSizeLimit(ScannerContext.LimitScope, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
 
setSkipChecks(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
setSleepInterval(long) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
 
setSlop(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
setSlop(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
setSmall(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Set whether this scan is a small scan
setSmall(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setSmallIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setSnapshotDirs(Configuration, Map<String, Path>) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
 
setSnapshotHandlerForTesting(TableName, SnapshotSentinel) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Set the handler for the current snapshot
setSnapshotToScans(Configuration, Map<String, Collection<Scan>>) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
Push snapshotScans to conf (under the key MultiTableSnapshotInputFormatImpl.SNAPSHOT_TO_SCANS_KEY)
setSocketSendBufSize(int) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
Sets the socket buffer size used for responding to RPCs.
setSocketSendBufSize(int) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
 
setSortColumns(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setSortColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setSortedColumns(List<TColumn>) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
setSortedColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
setSortField() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
 
setSortFieldAndFields(Field, List<Field>) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
setSource(MetricsThriftServerSource) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
setSplit(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
setSplit(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setSplitIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setSplitOrMergeEnabled(boolean, boolean, Admin.MasterSwitchType...) - Method in interface org.apache.hadoop.hbase.client.Admin
Turn the Split or Merge switches on or off.
setSplitOrMergeEnabled(boolean, boolean, Admin.MasterSwitchType...) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
setSplitOrMergeEnabled(RpcController, MasterProtos.SetSplitOrMergeEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
setSplitOrMergeEnabled(boolean, Admin.MasterSwitchType) - Method in class org.apache.hadoop.hbase.zookeeper.SplitOrMergeTracker
 
setSplitPoint(byte[]) - Method in class org.apache.hadoop.hbase.master.normalizer.SplitNormalizationPlan
 
setStackIndexes(List<Integer>) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called on store load to initialize the Procedure internals after the creation/deserialization.
setStartAndPrefix(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
the prefix (and thus start row) of the keys you want
setStartAndPrefix(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
setStartAndPrefixIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
setStartCode(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
setStartCode(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int64 startCode = 2;
setStartCode(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
setStartCodeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
setStartKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
setStartKey(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
 
setStartKey(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional bytes startKey = 2;
setStartKey(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setStartKey(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setStartKey(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setStartKey(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setStartKeyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setStartKeyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.
use Scan.withStartRow(byte[]) instead. This method may change the inclusive of the stop row to keep compatible with the old behavior.
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
setStartRow(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bytes startRow = 1;
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
Starting row in table to scan.
setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
Starting row in table to scan.
setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
Starting row in table to scan.
setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Starting row in table to scan.
setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setStartTime(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
setStartTime(long) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called on store load to initialize the Procedure internals after the creation/deserialization.
setStartTime(long) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
setStartTime(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int64 startTime = 5;
setStartTime(long) - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
setState(ProcedureProtos.ProcedureState) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
setStatistics(ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.Result
Deprecated.
setStatisticTracker(ServerStatisticTracker) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Set the tracker that should be used for tracking statistics about the server
setStatus(MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.CallRunner
 
setStatus(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
setStatus(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Deprecated.
use Scan.withStartRow(byte[]) instead. This method may change the inclusive of the stop row to keep compatible with the old behavior.
setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
row to stop scanning on.
setStopRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
row to stop scanning on.
setStopRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setStopRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setStopRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setStopRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
setStopRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
setStopRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setStopRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setStoragePolicy(FileSystem, Configuration, Path, String, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Sets storage policy for given path according to config setting.
setStorefileIndexSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
setStorefileIndexSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefileIndexSizeMB = 6;
setStorefiles(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
setStorefiles(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefiles = 3;
setStorefileSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
setStorefileSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefileSizeMB = 4;
setStores(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
setStores(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 stores = 2;
setStub(AdminProtos.AdminService.BlockingInterface) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
setSuccess(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
setSuccess(Map<ByteBuffer, ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
setSuccess(TRegionInfo) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
setSuccess(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
setSuccess(List<TRegionInfo>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
setSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
setSuccess(List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
setSuccess(List<Boolean>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
setSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
setSuccess(List<THRegionLocation>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
setSuccess(List<TResult>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
setSuccess(THRegionLocation) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
setSuccess(List<TResult>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
setSuccess(List<TResult>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
setSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
setTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
the table to append the value on
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
to check in and delete from
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
to check in and delete from
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
to check in and put to
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
the table to delete from
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
the table to delete from
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
the table to check on
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
the table to check on
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
the table to get from
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
the table to get from
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
the table to get the Scanner for
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
the table to increment the value on
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
table to apply the mutations
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
the table to get the Scanner for
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
the table to put data in
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
the table to put data in
setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
setTableCFsMap(Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
setTableFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Set the table filter regex
setTableGroupPermissions(String, TableName, List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Overwrites the existing permission set for a group and triggers an update for zookeeper synchronization.
setTableInfo(HBaseFsck.TableInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Set the TableInfo used by all HRegionInfos fabricated by other callbacks
setTableInfo(HBaseFsck.TableInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Set the TableInfo used by all HRegionInfos fabricated by other callbacks
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
setTableName(TableName) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
 
setTableName(TableName) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
name of table to create
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
name of table to delete
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
name of the table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
name of the table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
table name
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
name of the table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
name of the table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
table name
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
name of the table to check
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
name of table
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
setTableNameOrRegionName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
setTableNameOrRegionName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
setTableNameOrRegionName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
setTableNameOrRegionName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
setTableNameOrRegionNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
setTableNameOrRegionNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
setTableQuota(TableName, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to set the TableRecordReader.
setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Allows subclasses to set the TableRecordReader.
setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to set the TableRecordReader.
setTables(List<TableModel>) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
 
SettableSequenceId - Interface in org.apache.hadoop.hbase
Using this Interface one can mark a Cell as Sequence stampable.
setTableState(TableName, ZooKeeperProtos.Table.State) - Method in interface org.apache.hadoop.hbase.TableStateManager
Sets the table into desired state.
setTableState(TableName, ZooKeeperProtos.Table.State) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
Sets table state in ZK.
setTableStateIfInStates(TableName, ZooKeeperProtos.Table.State, ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
Sets the specified table into the newState, but only if the table is already in one of the possibleCurrentStates (otherwise no operation is performed).
setTableStateIfInStates(TableName, ZooKeeperProtos.Table.State, ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
Checks and sets table state in ZK.
setTableStateIfNotInStates(TableName, ZooKeeperProtos.Table.State, ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
Sets the specified table into the newState, but only if the table is NOT in one of the possibleCurrentStates (otherwise no operation is performed).
setTableStateIfNotInStates(TableName, ZooKeeperProtos.Table.State, ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
Checks and sets table state in ZK.
setTableStateToDisabled(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
Mark table state to Disabled
setTableStateToDisabling(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
Mark table state to Disabling
setTableStateToEnabled(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
Mark table state to Enabled
setTableStateToEnabling(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
Mark table state to Enabling
SettableTimestamp - Interface in org.apache.hadoop.hbase
Using this Interface one can mark a Cell as timestamp changeable.
setTableUserPermissions(String, TableName, List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Overwrites the existing permission set for a given user for a table, and triggers an update for zookeeper synchronization.
setTagCompressionContext(TagCompressionContext) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
 
setTagCompressionContext(TagCompressionContext) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
setTags(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setTags(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setTagsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setTagsOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setTappend(TAppend) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
the TAppend to append
setTappendIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
setTarget(String) - Method in class org.apache.hadoop.hbase.AsyncConsoleAppender
 
setTargetTableName(String[]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
 
setTaskMonitor(TaskMonitor) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
 
setTaskMonitor(TaskMonitor) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
setTaskNode(String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
 
setTdelete(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
the TDelete to execute if the check succeeds
setTdelete(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
the TDelete to delete
setTdeleteIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
setTdeleteIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
setTdeletes(List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
list of TDeletes to delete
setTdeletesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
setTEST_FORCE_REFRESH(boolean) - Static method in class org.apache.hadoop.hbase.quotas.QuotaCache
 
setTestSkipMergeHandling(boolean) - Static method in class org.apache.hadoop.hbase.master.AssignmentManager
 
setTestSkipSplitHandling(boolean) - Static method in class org.apache.hadoop.hbase.master.AssignmentManager
 
setTget(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
the TGet to check for
setTget(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
the TGet to fetch
setTgetIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
setTgetIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
setTgets(List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
a list of TGets to check for
setTgets(List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
a list of TGets to fetch, the Result list will have the Results at corresponding positions or null if there was an error
setTgetsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
setTgetsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
setThird(C) - Method in class org.apache.hadoop.hbase.util.Triple
 
setThreads(int, int) - Method in class org.apache.hadoop.hbase.http.HttpServer
Set the min, max number of worker threads (simultaneous connections).
setTickTime(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
setTimeLag(long) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
We are interested in only those tables that have not changed their state in hbase:meta during the last few seconds specified by hbase.admin.fsck.timelag
setTimeLimit(ScannerContext.LimitScope, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
 
setTimeout(int) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
setTimeoutFailure() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
setTimer(long) - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
setTimer(long) - Method in class org.apache.hadoop.hbase.hbtop.screen.Screen
 
setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Get
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Increment
Sets the TimeRange to be used on the Get for this increment.
setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Scan
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
setTimeRange(TTimeRange) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setTimeRange(TTimeRange) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setTimeRangeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setTimeRangeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setTimestamp(Cell, long) - Static method in class org.apache.hadoop.hbase.CellUtil
Sets the given timestamp to the cell.
setTimestamp(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
Sets the given timestamp to the cell.
setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Delete
Set the timestamp of the delete.
setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Get
Get versions of columns with the specified timestamp.
setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Scan
Get versions of columns with the specified timestamp.
setTimestamp(long) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
optional uint64 timestamp = 3;
setTimestamp(long) - Method in class org.apache.hadoop.hbase.KeyValue
 
setTimestamp(byte[], int) - Method in class org.apache.hadoop.hbase.KeyValue
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.master.RegionState
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional int64 timestamp = 3;
setTimestamp(long) - Method in interface org.apache.hadoop.hbase.SettableTimestamp
Sets with the given timestamp.
setTimestamp(byte[], int) - Method in interface org.apache.hadoop.hbase.SettableTimestamp
Sets with the given timestamp.
setTimestamp(long) - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
setTimestamp(byte[], int) - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
timestamp
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
timestamp
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
timestamp
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
timestamp
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
timestamp
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
timestamp
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
timestamp
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
timestamp
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
timestamp
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setTimestampDeltaWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setTimestampFields(LongEncoder) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setTimestampIndexWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setTimeToLive(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setTimeToLive(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setTimeToLiveIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
setTimeUnit(TimeUnit) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
 
setTincrement(TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
the TIncrement to increment
setTincrementIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
setTitle(String) - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
 
setToken(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setTokenBytes(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
 
setTokenOffset(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setToNewRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
Set the row when there is change in row
setTotalCompactingKVs(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
setTotalCompactingKVs(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 totalCompactingKVs = 12;
setTotalStaticBloomSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
setTotalStaticBloomSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 totalStaticBloomSizeKB = 11;
setTotalStaticIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
setTotalStaticIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 totalStaticIndexSizeKB = 10;
setTotalUncompressedBytes(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setTput(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
the TPut to put if the check succeeds
setTput(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
the TPut to put
setTputIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setTputIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
setTputs(List<TPut>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
a list of TPuts to commit
setTputsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
setTrackMetrics(boolean) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
 
setTrowMutations(TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
mutations to apply
setTrowMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
setTscan(TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
the scan object to get a Scanner for
setTscan(TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
the scan object to get a Scanner for
setTscanIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
setTscanIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
setTTL(long) - Method in class org.apache.hadoop.hbase.client.Append
 
setTTL(long) - Method in class org.apache.hadoop.hbase.client.Delete
 
setTTL(long) - Method in class org.apache.hadoop.hbase.client.Increment
 
setTTL(long) - Method in class org.apache.hadoop.hbase.client.Mutation
Set the TTL desired for the result of the mutation, in milliseconds.
setTTL(long) - Method in class org.apache.hadoop.hbase.client.Put
 
setTtl(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional int32 ttl = 3;
setUnassigned() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
setUnblockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.hadoop.hbase.util.HasThread
 
setUncompressedDataIndexSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setUnderline(boolean) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, ImmutableBytesWritable>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
 
setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
 
setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueImporter
 
setup(Mapper<ImmutableBytesWritable, Result, Import.KeyValueWritableComparable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueSortImporter
 
setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map
 
setup(Reducer<ImmutableBytesWritable, Put, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutSortReducer
 
setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
 
setup(Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
Handles initializing this class with objects specific to it (i.e., the parser).
setup(Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
Handles initializing this class with objects specific to it (i.e., the parser).
setup(Mapper<LongWritable, Text, ImmutableBytesWritable, Text>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
Handles initializing this class with objects specific to it (i.e., the parser).
setup(Mapper<WALKey, WALEdit, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
 
setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
 
setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
 
setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
 
setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
setup(RegionServerServices) - Method in interface org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
Setup controller for the given region server.
setupClusterConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Setup our cluster connection if not already initialized.
setupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
setupMasterlessConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Setup the connection class, so that it will not depend on master being online.
setupRegionReplicaReplication(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
Create replication peer for replicating to region replicas if needed.
setupSaslHandler(ChannelPipeline) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
 
setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
Deprecated.
Removed in HBase 2.0+ as a part of removing protobuf from our API
setupShortCircuitRead(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Do our short circuit read setup.
setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
setUserFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Set the user filter regex
setUsernameConfKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
setUserProviderForTesting(Configuration, Class<? extends UserProvider>) - Static method in class org.apache.hadoop.hbase.security.UserProvider
Set the UserProvider in the given configuration that should be instantiated
setUserQuota(String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
setUserQuota(String, TableName, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
setUserQuota(String, String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
 
setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Setter for storing metadata as a (key, value) pair in HTableDescriptor.values map
setValue(ImmutableBytesWritable, ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Setter for storing metadata as a (key, value) pair in HTableDescriptor.values map
setValue(V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Set the value of this entry.
setValue(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
 
setValue(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string value = 2;
setValue(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
required string value = 2;
setValue(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string value = 2;
setValue(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
amount to increment by
setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
the expected value for the column parameter, if not provided the check is for the non-existence of the column in question
setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
the expected value, if not provided the check is for the non-existence of the column in question
setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
the expected value to be compared against, if not provided the check is for the non-existence of the column in question
setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
the expected value, if not provided the check is for the non-existence of the column in question
setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setValue(long) - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
 
setValueBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string value = 2;
setValueBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property.Builder
required string value = 2;
setValueBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string value = 2;
setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setValueLengthWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setValueOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setValues(int, CellMessage.Cell) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
setValues(int, CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
setValues(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
setValuesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
setVersion(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setVersion(int) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
 
setVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
 
setVersion(byte) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Sets version of file system
setVersion(FileSystem, Path, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Sets version of file system
setVersion(FileSystem, Path, String, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Sets version of file system
setVersionIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
setVersionOfOfflineNode(int) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
 
setVersions(int, int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Set minimum and maximum versions to keep
setVersionsDeleted(long) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
optional uint64 versionsDeleted = 2;
setVictimCache(BlockCache) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
setWalEdit(int, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
Sets the walEdit for the operation(Mutation) at the specified position.
setWalGroupId(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
 
setWALRootDir(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
setWarnTime(long) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
setWatchIfNodeExists(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Watch the specified znode, but only if exists.
setWithPrefix(Configuration, String, Iterable<Map.Entry<String, String>>) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Sets all the entries in the provided Map<String, String> as properties in the given Configuration.
setWorkerState(ReplicationSource.WorkerState) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.ReplicationSourceShipperThread
Set the worker state
setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
Deprecated.
Going away when we drop public support for HTableInterface.
setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.client.HTable
Sets the size of the buffer in bytes.
setWriteBufferSize(long) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated.
setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
setWriteBufferSize(long) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
as of 1.0.1 (should not have been in 1.0.0). Replaced by BufferedMutator and BufferedMutatorParams.writeBufferSize(long)
setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
setWriteEntry(MultiVersionConcurrencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.wal.WALKey
 
setWriteLatency(long) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
setWriteRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
 
setWriteRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 writeRequestsCount = 8;
setWriteRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
 
setWriteRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
setWriteRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.Table
Set timeout (millisecond) of each rpc write request in operations of this Table instance, will override the value of hbase.rpc.write.timeout in configuration.
setWriteRpcTimeout(int) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
setWriteSuccess() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
 
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Append
Deprecated.
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Increment
Deprecated.
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
setWriteToWALIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
setZnodeVersion(int) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination.ZkRegionMergeDetails
 
setZnodeVersion(int) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination.ZkSplitTransactionDetails
 
SEVENTY_FIFTH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
shallowCopy() - Method in class org.apache.hadoop.hbase.KeyValue
Creates a shallow copy of this KeyValue, reusing the data byte buffer.
shallowCopy() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
shallowCopy() - Method in interface org.apache.hadoop.hbase.util.ByteRange
Create a new ByteRange that points at this range's byte[].
shallowCopy() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
shallowCopySubRange(int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Create a new ByteRange that points at this range's byte[].
shallowCopySubRange(int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
shipBatch(long, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Convience method to apply changes to metrics do to shipping a batch of logs.
shipBatch(long, int, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Convience method to apply changes to metrics do to shipping a batch of logs.
shipEdits(ReplicationSourceWALReaderThread.WALEntryBatch) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.ReplicationSourceShipperThread
Do the shipping logic
shouldArchiveTable(String) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
Determine if the given table should or should not allow its hfiles to be deleted in the archive
shouldBeOnMaster(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Check if a region belongs to some small system table.
shouldBypass() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
For use by the coprocessor framework.
shouldCacheBlockOnRead(BlockType.BlockCategory) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Should we cache a block of a particular category? We always cache important blocks such as index blocks, as long as the block cache is available.
shouldCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCacheBloomsOnWrite()} instead.
shouldCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
shouldCacheCompressed(BlockType.BlockCategory) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
shouldCacheDataCompressed() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
shouldCacheDataInL1() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCacheDataInL1()} instead.
shouldCacheDataOnRead() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Returns whether the DATA blocks of this HFile should be cached on read or not (we always cache the meta blocks, the INDEX and BLOOM blocks).
shouldCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCacheDataOnWrite()} instead.
shouldCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCacheIndexesOnWrite() instead.
shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
shouldComplete() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
For use by the coprocessor framework.
shouldCompressTags() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isCompressTags() instead.
shouldDropBehind - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
shouldDropBehindCompaction() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
shouldEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isEvictBlocksOnClose()} instead.
shouldEvictOnClose() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
shouldFixVersionFile() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
shouldIgnorePreCheckPermission() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
shouldIncludeMemstoreTS() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
shouldKillBeforeStoreUpdate() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.Testing
 
shouldLockOnCacheMiss(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
If we make sure the block could not be cached, we will not acquire the lock otherwise we will acquire lock
shouldPerformMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
 
shouldPerformMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
 
shouldPerformMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.FIFOCompactionPolicy
 
shouldPerformMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
 
shouldPerformMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
 
shouldPerformMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
 
shouldPrefetchBlocksOnOpen() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 1.0.0 (HBASE-10870). This will be removed in HBase 2.0.0. Use HColumnDescriptor.isPrefetchBlocksOnOpen()}} instead.
shouldPrefetchOnOpen() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
shouldReadBlockFromCache(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Return true if we may find this type of block in block cache.
shouldReplaceExistingCacheBlock(BlockCache, BlockCacheKey, Cacheable) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
Because of the region splitting, it's possible that the split key locate in the middle of a block.
shouldReplayRecoveredEdits(HRegion) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
Returns whether to replay the recovered edits to flush the results.
shouldRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
 
shouldSeek(Scan, Store, long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Check if this memstore may contain the required keys
shouldSidelineBigOverlaps() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
 
shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
 
shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy
 
shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
 
shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
 
shouldUseHBaseChecksum() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
 
shouldUseScanner(Scan, Store, long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
 
shouldUseScanner(Scan, Store, long) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Allows to filter out scanners (both StoreFile and memstore) that we don't want to use based on criteria such as Bloom filters and timestamp ranges.
shouldUseScanner(Scan, Store, long) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
 
shouldUseScanner(Scan, Store, long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
shouldUseThisHostnameInstead() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
shouldWaitClientAck(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
shouldWaitClientAck(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
shouldWaitClientAck(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
shouldWaitClientAck(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
By default, the executor will keep the procedure result around util the eviction TTL is expired.
shouldWriteBlock(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Whether there is an inline block ready to be written.
shouldWriteBlock(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
Determines whether there is a new block to be written out.
shouldWriteBlock(boolean) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
 
showField(int, Field, boolean, boolean, int, int, boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
 
showFieldScreen(String, List<Field>, EnumMap<Field, Boolean>, int, int, int, boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
 
showFilters(List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenView
 
showHelpScreen(long, CommandDescription[]) - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
 
showInput(String, String, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
 
showMessage(String) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
 
showMode(int, Mode, boolean, int, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
 
showModeScreen(Mode, List<Mode>, int, int, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
 
showScreenDescription(String) - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
 
showTopScreen(Summary, List<Header>, List<Record>, Record) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
 
SHUFFLE_MAPS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Specify if we have to shuffle the map tasks.
shutdown() - Method in class org.apache.hadoop.hbase.ChoreService
shutdown the service.
shutdown() - Method in interface org.apache.hadoop.hbase.client.Admin
Shuts down the HBase cluster
shutdown() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Shuts down the HBase cluster
shutdown() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
 
shutdown() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
Clean up the environment
shutdown(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
shutdown() - Method in class org.apache.hadoop.hbase.executor.ExecutorService
 
shutdown() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Shutdown the cache.
shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
No operation for the shutdown in the memory IO engine
shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
Close the file
shutdown() - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
Shutdown the IOEngine
shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
shutdown() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Shut down the mini HBase cluster
shutdown() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Shutdown the threadpool executor service
shutdown() - Method in class org.apache.hadoop.hbase.master.HMaster
 
shutdown(RpcController, MasterProtos.ShutdownRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
shutdown() - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
shutdown() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
shutdown() - Method in class org.apache.hadoop.hbase.rest.client.Client
Shut down the client.
shutdown() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
 
shutdown() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
Called when cache is no longer needed so that it can perform cleanup operations
shutdown(List<JVMClusterUtil.MasterThread>, List<JVMClusterUtil.RegionServerThread>) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
 
shutdown() - Method in class org.apache.hadoop.hbase.util.MetaUtils
Closes catalog regions if open.
shutdown(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
Shutdown passed thread using isAlive and join.
shutdown(Thread, long) - Static method in class org.apache.hadoop.hbase.util.Threads
Shutdown passed thread using isAlive and join.
shutdown() - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
 
shutdown() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
shutdown() - Method in interface org.apache.hadoop.hbase.wal.WAL
Stop accepting new writes.
shutdown() - Method in class org.apache.hadoop.hbase.wal.WALFactory
Tell the underlying WAL providers to shut down, but do not clean up underlying storage.
shutdown() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
persist outstanding WALs to storage and stop accepting new appends.
shutdown() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
shutdownCluster() - Method in class org.apache.hadoop.hbase.master.ServerManager
 
ShutdownHook - Class in org.apache.hadoop.hbase.regionserver
Manage regionserver shutdown hooks.
ShutdownHook() - Constructor for class org.apache.hadoop.hbase.regionserver.ShutdownHook
 
ShutdownHookManager - Class in org.apache.hadoop.hbase.util
This class provides ShutdownHookManager shims for HBase to interact with the Hadoop 1.0.x and the Hadoop 2.0+ series.
ShutdownHookManager() - Constructor for class org.apache.hadoop.hbase.util.ShutdownHookManager
 
shutdownNow() - Method in class org.apache.hadoop.hbase.master.cleaner.DirScanPool
 
signalAll() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
signalAll() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
In case the class is blocking on poll() waiting for items to be added, this method should awake poll() and poll() should return.
signalAll() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
 
signalAll() - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
 
SimpleByteRange - Class in org.apache.hadoop.hbase.util
A read only version of the ByteRange.
SimpleByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
 
SimpleByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
 
SimpleByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
Create a new ByteRange over the provided bytes.
SimpleByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
Create a new ByteRange over the provided bytes.
SimpleLoadBalancer - Class in org.apache.hadoop.hbase.master.balancer
Makes decisions about the placement and movement of Regions across RegionServers.
SimpleLoadBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
 
SimpleMutableByteRange - Class in org.apache.hadoop.hbase.util
A basic mutable ByteRange implementation.
SimpleMutableByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
Create a new ByteRange lacking a backing array and with an undefined viewport.
SimpleMutableByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
Create a new ByteRange over a new backing array of size capacity.
SimpleMutableByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
Create a new ByteRange over the provided bytes.
SimpleMutableByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
Create a new ByteRange over the provided bytes.
SimplePositionedByteRange - Class in org.apache.hadoop.hbase.util
Extends the basic SimpleMutableByteRange implementation with position support and it is a readonly version.
SimplePositionedByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
Create a new PositionedByteRange lacking a backing array and with an undefined viewport.
SimplePositionedByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
Create a new PositionedByteRange over a new backing array of size capacity.
SimplePositionedByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
Create a new PositionedByteRange over the provided bytes.
SimplePositionedByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
Create a new PositionedByteRange over the provided bytes.
SimplePositionedMutableByteRange - Class in org.apache.hadoop.hbase.util
Extends the basic AbstractPositionedByteRange implementation with position support and it is a mutable version.
SimplePositionedMutableByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
Create a new PositionedByteRange lacking a backing array and with an undefined viewport.
SimplePositionedMutableByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
Create a new PositionedByteRange over a new backing array of size capacity.
SimplePositionedMutableByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
Create a new PositionedByteRange over the provided bytes.
SimplePositionedMutableByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
Create a new PositionedByteRange over the provided bytes.
SimpleRegionNormalizer - Class in org.apache.hadoop.hbase.master.normalizer
Simple implementation of region normalizer.
SimpleRegionNormalizer() - Constructor for class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
 
SimpleRpcScheduler - Class in org.apache.hadoop.hbase.ipc
The default scheduler.
SimpleRpcScheduler(Configuration, int, int, int, PriorityFunction, Abortable, int) - Constructor for class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
SimpleRpcScheduler(Configuration, int, int, int, PriorityFunction, int) - Constructor for class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
SimpleRpcSchedulerFactory - Class in org.apache.hadoop.hbase.regionserver
Constructs a SimpleRpcScheduler.
SimpleRpcSchedulerFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
 
SimpleScanLabelGenerator - Class in org.apache.hadoop.hbase.security.visibility
This is a simple implementation for ScanLabelGenerator.
SimpleScanLabelGenerator() - Constructor for class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
 
SimpleTotalOrderPartitioner<VALUE> - Class in org.apache.hadoop.hbase.mapreduce
A partitioner that takes start and end keys and uses bigdecimal to figure which reduce a key belongs to.
SimpleTotalOrderPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
SINGLE_QUOTE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for a single quote
SingleColumnValueExcludeFilter - Class in org.apache.hadoop.hbase.filter
A Filter that checks a single column value, but does not emit the tested column.
SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
Constructor for binary compare of the value of a single column.
SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
Constructor for binary compare of the value of a single column.
SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
Constructor for protobuf deserialization only.
SingleColumnValueFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter cells based on value.
SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Constructor for binary compare of the value of a single column.
SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Constructor for binary compare of the value of a single column.
SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Constructor for protobuf deserialization only.
SingletonCoprocessorService - Interface in org.apache.hadoop.hbase.coprocessor
Coprocessor endpoints registered once per server and providing protobuf services should implement this interface and return the Service instance via SingletonCoprocessorService.getService().
sink - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
SINK_AGE_OF_LAST_APPLIED_OP - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
 
SINK_APPLIED_BATCHES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
 
SINK_APPLIED_HFILES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
 
SINK_APPLIED_OPS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
 
sinkToString() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
sinkToString
size() - Method in class org.apache.hadoop.hbase.client.MultiAction
Get the total number of Actions
size() - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
size() - Method in class org.apache.hadoop.hbase.client.Mutation
Number of KeyValues carried by this Mutation.
size() - Method in class org.apache.hadoop.hbase.client.Result
 
size() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
size() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
size() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
Size - Class in org.apache.hadoop.hbase.hbtop.field
It is used to represent the size with different units.
Size(double, Size.Unit) - Constructor for class org.apache.hadoop.hbase.hbtop.field.Size
 
size() - Method in class org.apache.hadoop.hbase.hbtop.Record
 
size() - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
 
size() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
size() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Returns the total size of the block cache, in bytes.
size() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
size() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
size() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
size() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
size() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
size() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
size - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
size() - Method in class org.apache.hadoop.hbase.master.DeadServer
 
size() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
size() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
Returns the number of elements in this collection.
size() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
 
size() - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
 
size() - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
 
size() - Method in class org.apache.hadoop.hbase.RegionLocations
Returns the size of the list even if some of the elements might be null.
size() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
size() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
 
size() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Gets the size (number of entries) of the map.
size() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
 
size() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
 
size() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
size() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
size() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
size() - Method in class org.apache.hadoop.hbase.util.BoundedArrayQueue
 
size() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
size() - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
size - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists
 
size() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
 
size() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
size() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
size(K) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
size() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
size() - Method in class org.apache.hadoop.hbase.util.SortedList
 
size() - Method in class org.apache.hadoop.hbase.util.WeakObjectPool
Returns an estimated count of objects kept in the pool.
Size.Unit - Enum in org.apache.hadoop.hbase.hbtop.field
 
SIZE_TO_SPLIT_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
The size the stripe should achieve to be considered for splitting into multiple stripes.
SIZE_VALUE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
SizedCellScanner - Interface in org.apache.hadoop.hbase.io
A CellScanner that knows its size in memory in bytes.
sizeIndex() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
sizeIndexOfAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
sizeOf(byte[], int) - Static method in class org.apache.hadoop.hbase.util.ClassSize
 
SIZEOF_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of boolean in bytes
SIZEOF_BYTE - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of byte in bytes
SIZEOF_CHAR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of char in bytes
SIZEOF_DOUBLE - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of double in bytes
SIZEOF_FLOAT - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of float in bytes
SIZEOF_INT - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of int in bytes
SIZEOF_LONG - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of long in bytes
SIZEOF_SHORT - Static variable in class org.apache.hadoop.hbase.util.Bytes
Size of short in bytes
sizeOfAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
sizeToString(long) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
skip(long) - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
Skips n bytes of input from this input stream.
skip(long) - Method in class org.apache.hadoop.hbase.io.LimitInputStream
 
skip(PositionedByteRange) - Method in interface org.apache.hadoop.hbase.types.DataType
Skip src's position forward over one encoded value.
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.PBCell
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawByte
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawBytes
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawDouble
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawFloat
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawInteger
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawLong
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawShort
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawString
 
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
 
skip() - Method in class org.apache.hadoop.hbase.types.StructIterator
Bypass the next encoded value.
skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
Skip src's position forward over one encoded value.
skip(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Increment position in buffer.
skip(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Skip buff's position forward over one encoded value.
SKIP_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
SKIP Array
SKIP_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
SKIP_EMPTY_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
SKIP_LINES_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
SkipFilter - Class in org.apache.hadoop.hbase.filter
A wrapper filter that filters an entire row if any of the Cell checks do not pass.
SkipFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.SkipFilter
 
skipKVsNewerThanReadpoint() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
skipLargeFiles(ArrayList<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
 
skipNext() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureIterator
Skip the next procedure
skippedEdits - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
skipSleepCycle() - Method in class org.apache.hadoop.hbase.util.Sleeper
If currently asleep, stops sleeping; if not asleep, will skip the next sleep cycle.
skipStoreFileRangeCheck() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
skipStoreFileRangeCheck(String) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
sleep(long, int) - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
sleep(long, int) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
sleep(long, int) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
sleep(long, int) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
 
sleep() - Method in class org.apache.hadoop.hbase.util.Sleeper
Sleep for period.
sleep(long) - Method in class org.apache.hadoop.hbase.util.Sleeper
Sleep for period adjusted by passed startTime
sleep(long) - Static method in class org.apache.hadoop.hbase.util.Threads
If interrupted, just prints out the interrupt on STDOUT, resets interrupt and returns
sleeper - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
Sleeper - Class in org.apache.hadoop.hbase.util
Sleeper for current thread.
Sleeper(int, Stoppable) - Constructor for class org.apache.hadoop.hbase.util.Sleeper
 
sleepForRetries(String, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
Do the sleeping logic
sleepForRetries(String, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
Do the sleeping logic
sleepUntilNextRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
Sleep for a back off time as supplied by the backoff policy, and increases the attempts
sleepWithoutInterrupt(long) - Static method in class org.apache.hadoop.hbase.util.Threads
Sleeps for the given amount of time even if interrupted.
slop - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
SLOW_APPEND_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
SLOW_APPEND_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
SLOW_APPEND_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SLOW_APPEND_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SLOW_DELETE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SLOW_DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SLOW_GET_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SLOW_GET_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SLOW_INCREMENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SLOW_INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SLOW_PUT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SLOW_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SLOW_RESPONSE_NANO_SEC - Static variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
SLOW_THRIFT_CALL_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
small - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
SMALL_COMPACTION_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SMALL_COMPACTION_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SMALL_COMPACTION_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
SMALL_COMPACTION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
SMALL_HFILE_DELETE_THREAD_NUMBER - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
SMALL_HFILE_QUEUE_INIT_SIZE - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
snapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Take a snapshot for the given table.
snapshot(byte[], TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
public void snapshot(final String snapshotName, Create a timestamp consistent snapshot for the given table.
snapshot(String, TableName, HBaseProtos.SnapshotDescription.Type) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
snapshot(HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
snapshot(String, TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Take a snapshot for the given table.
snapshot(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(byte[], byte[], HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create snapshot for the given table of given flush type.
snapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
public void snapshot(final String snapshotName, Create a timestamp consistent snapshot for the given table.
snapshot(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(String, TableName, HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create typed snapshot of the table.
snapshot(String, String, HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(String, byte[], HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
snapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Take a snapshot and wait for the server to complete that snapshot (blocking).
snapshot(RpcController, MasterProtos.SnapshotRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Triggers an asynchronous attempt to take a snapshot.
snapshot - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
snapshot() - Method in interface org.apache.hadoop.hbase.metrics.Histogram
Snapshot the current values in the Histogram
snapshot() - Method in class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
 
Snapshot - Interface in org.apache.hadoop.hbase.metrics
A statictical sample of histogram values.
snapshot() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Creates a snapshot of the current memstore.
snapshot() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Creates a snapshot of the current memstore.
snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Sample all the mutable metrics and put the snapshot in the builder
snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableFastCounter
 
snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableHistogram
 
snapshot(String, String, Histogram, MetricsRecordBuilder, boolean) - Static method in class org.apache.hadoop.metrics2.lib.MutableHistogram
 
snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
 
snapshot() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
Get a snapshot of the current values of all the tracked quantiles.
SNAPSHOT_CLEANER_DISABLE - Static variable in class org.apache.hadoop.hbase.HConstants
 
SNAPSHOT_CLONE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
 
SNAPSHOT_CLONE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
 
SNAPSHOT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Name of the directory to store all snapshots.
SNAPSHOT_LAYOUT_VERSION - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Version of the fs layout for a snapshot.
SNAPSHOT_MANIFEST_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2
 
SNAPSHOT_MANIFEST_SIZE_LIMIT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
SNAPSHOT_POOL_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
number of current operations running on the master
SNAPSHOT_POOL_THREADS_KEY - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Conf key for # of threads used by the SnapshotManager thread pool
SNAPSHOT_REQUEST_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
# of threads for snapshotting regions on the rs.
SNAPSHOT_REQUEST_THREADS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
Conf key for number of request threads to start snapshots on regionservers
SNAPSHOT_REQUEST_WAKE_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
Conf key for millis between checks to see if snapshot completed or if there are errors
SNAPSHOT_RESTORE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
 
SNAPSHOT_RESTORE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
 
SNAPSHOT_SENTINELS_CLEANUP_TIMEOUT_MILLS_DEFAULT - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
SNAPSHOT_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
 
SNAPSHOT_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
 
SNAPSHOT_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
Keep threads alive in request pool for max of 300 seconds
SNAPSHOT_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
SNAPSHOT_TIMEOUT_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
Conf key for max time to keep threads in snapshot request pool waiting
SNAPSHOT_TIMEOUT_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
SNAPSHOT_TMP_DIR_NAME - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Temporary directory under the snapshot directory to store in-progress snapshots
SNAPSHOT_TO_SCANS_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
 
SNAPSHOT_WORKING_DIR - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
The configuration property that determines the filepath of the snapshot base working directory
snapshotAllMetrics(MetricRegistry, MetricsCollector) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
Iterates over the MetricRegistry and adds them to the collector.
snapshotAllMetrics(MetricRegistry, MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
Iterates over the MetricRegistry and adds them to the builder.
snapshotAndReset() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
Resets the histogram for new counting.
SnapshotCreationException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when a snapshot could not be created due to a server-side error when taking the snapshot.
SnapshotCreationException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
Used internally by the RPC engine to pass the exception back to the client.
SnapshotCreationException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
Failure to create the specified snapshot.
SnapshotCreationException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
Deprecated.
since 1.3.0, will be removed in 3.0.0
SnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
Utility class to help manage SnapshotDesriptions.
SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter - Class in org.apache.hadoop.hbase.snapshot
Filter that only accepts completed snapshot directories
SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter
 
snapshotDisabledRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
Take a snapshot of the specified disabled region
SnapshotDoesNotExistException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when the server is looking for a snapshot, but can't find the snapshot on the filesystem.
SnapshotDoesNotExistException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
 
SnapshotDoesNotExistException(HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
Deprecated.
since 1.3.0, will be removed in 3.0.0
SnapshotExistsException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when a snapshot exists, but should not.
SnapshotExistsException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
Failure due to the snapshot already existing.
SnapshotExistsException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
Deprecated.
since 1.3.0, will be removed in 3.0.0
SnapshotFileCache - Class in org.apache.hadoop.hbase.master.snapshot
Intelligently keep track of all the files for all the snapshots.
SnapshotFileCache(Configuration, long, String, SnapshotFileCache.SnapshotFileInspector) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
Create a snapshot file cache for all snapshots under the specified [root]/.snapshot on the filesystem.
SnapshotFileCache(FileSystem, Path, long, long, String, SnapshotFileCache.SnapshotFileInspector) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
Create a snapshot file cache for all snapshots under the specified [root]/.snapshot on the filesystem
SnapshotFileCache.RefreshCacheTask - Class in org.apache.hadoop.hbase.master.snapshot
Simple helper task that just periodically attempts to refresh the cache
SnapshotFileCache.RefreshCacheTask() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache.RefreshCacheTask
 
SnapshotHFileCleaner - Class in org.apache.hadoop.hbase.master.snapshot
Implementation of a file cleaner that checks if a hfile is still used by snapshots of HBase tables.
SnapshotHFileCleaner() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
 
SnapshotInfo - Class in org.apache.hadoop.hbase.snapshot
Deprecated.
All the protos references will be changed to standalone POJOs from 2.0 onwards
SnapshotInfo() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotInfo
Deprecated.
 
SnapshotInfo.SnapshotStats - Class in org.apache.hadoop.hbase.snapshot
Deprecated.
Statistics about the snapshot How many store files and logs are in the archive How many store files and logs are shared with the table Total store files and logs size and shared amount
SNAPSHOTINFO_FILE - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
The file contains the snapshot basic information and it is under the directory of a snapshot.
SnapshotManager - Class in org.apache.hadoop.hbase.master.snapshot
This class manages the procedure of taking and restoring snapshots.
SnapshotManager() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
snapshotManager - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
snapshotManifest - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
SnapshotManifest - Class in org.apache.hadoop.hbase.snapshot
Utility class to help read/write the Snapshot Manifest.
SnapshotManifestV1 - Class in org.apache.hadoop.hbase.snapshot
DO NOT USE DIRECTLY.
SnapshotManifestV2 - Class in org.apache.hadoop.hbase.snapshot
DO NOT USE DIRECTLY.
SnapshotOfRegionAssignmentFromMeta - Class in org.apache.hadoop.hbase.master
Used internally for reading meta and constructing datastructures that are then queried, for things like regions to regionservers, table to regions, etc.
SnapshotOfRegionAssignmentFromMeta(Connection) - Constructor for class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
 
SnapshotOfRegionAssignmentFromMeta(Connection, Set<TableName>, boolean) - Constructor for class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
 
SnapshotReferenceUtil - Class in org.apache.hadoop.hbase.snapshot
Utility methods for interacting with the snapshot referenced files.
SnapshotReferenceUtil.SnapshotVisitor - Interface in org.apache.hadoop.hbase.snapshot
 
SnapshotReferenceUtil.StoreFileVisitor - Interface in org.apache.hadoop.hbase.snapshot
 
snapshotRegions(List<Pair<HRegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.DisabledTableSnapshotHandler
 
snapshotRegions(List<Pair<HRegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.EnabledTableSnapshotHandler
This method kicks off a snapshot procedure.
snapshotRegions(List<Pair<HRegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
Snapshot the specified regions
SnapshotSentinel - Interface in org.apache.hadoop.hbase.master
Watch the current snapshot under process
snapshotTable - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
socket - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
SOCKET_RETRY_WAIT_MS - Static variable in class org.apache.hadoop.hbase.HConstants
The delay when re-trying a socket operation in a loop (HBASE-4712)
SOCKET_TIMEOUT_CONNECT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
SOCKET_TIMEOUT_READ - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
How long we wait when we wait for an answer.
SOCKET_TIMEOUT_WRITE - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
socketFactory - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcClient
 
socketSendBufferSize - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
solve() - Method in class org.apache.hadoop.hbase.util.MunkresAssignment
Get the optimal assignments.
sortAndMerge(List<MultiRowRangeFilter.RowRange>) - Static method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
sort the ranges and if the ranges with overlap, then merge them.
sortColumns - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
 
SORTED_ORDINAL_SERIALIZATION_FORMAT - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Visibility serialization version format.
SORTED_ORDINAL_SERIALIZATION_FORMAT_TAG - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
 
SORTED_ORDINAL_SERIALIZATION_FORMAT_TAG_VAL - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
Byte representation of the visibility_serialization_version
sortedColumns - Variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
SortedCompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
An abstract compaction policy that select files on seq id order.
SortedCompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
 
SortedCopyOnWriteSet<E> - Class in org.apache.hadoop.hbase.util
Simple SortedSet implementation that uses an internal TreeSet to provide ordering.
SortedCopyOnWriteSet() - Constructor for class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
SortedCopyOnWriteSet(Collection<? extends E>) - Constructor for class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
SortedCopyOnWriteSet(Comparator<? super E>) - Constructor for class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
sortedIndexByInsertionId - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
sortedIndexByUniqueIndex - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
SortedList<E> - Class in org.apache.hadoop.hbase.util
Simple sorted list implementation that uses ArrayList as the underlying collection so we can support RandomAccess.
SortedList(Comparator<? super E>) - Constructor for class org.apache.hadoop.hbase.util.SortedList
Constructs an empty list with the default initial capacity that will be sorted using the given comparator.
SortedList(Collection<? extends E>, Comparator<? super E>) - Constructor for class org.apache.hadoop.hbase.util.SortedList
Constructs a list containing the elements of the given collection, in the order returned by the collection's iterator, that will be sorted with the given comparator.
sortedPrefixes - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
sortedRanges - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
sortedUniqueValues - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
SOURCE_AGE_OF_LAST_SHIPPED_OP - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_CLOSED_LOGS_WITH_UNKNOWN_LENGTH - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_COMPLETED_LOGS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_COMPLETED_RECOVERY_QUEUES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_FAILED_RECOVERY_QUEUES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_LOG_EDITS_FILTERED - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_LOG_READ_IN_BYTES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_LOG_READ_IN_EDITS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_REPEATED_LOG_FILE_BYTES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_RESTARTED_LOG_READING - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_SHIPPED_BATCHES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_SHIPPED_BYTES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_SHIPPED_HFILES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_SHIPPED_KBS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
Deprecated.
SOURCE_SHIPPED_OPS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_SIZE_OF_HFILE_REFS_QUEUE - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_SIZE_OF_LOG_QUEUE - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_UNCLEANLY_CLOSED_IGNORED_IN_BYTES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SOURCE_UNCLEANLY_CLOSED_LOGS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
SourceFSConfigurationProvider - Interface in org.apache.hadoop.hbase.replication.regionserver
Interface that defines how a region server in peer cluster will get source cluster file system configurations.
sourceScanner - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
Source scanner that is tracking KV count; may be null if source is not StoreScanner
sourceToString() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
sourceToString
SPAN_RECEIVERS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.trace.SpanReceiverHost
 
SpanReceiverHost - Class in org.apache.hadoop.hbase.trace
This class provides functions for reading the names of SpanReceivers from hbase-site.xml, adding those SpanReceivers to the Tracer, and closing those SpanReceivers when appropriate.
SPECIFIC_WRITE_THREAD - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
split(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Split a table.
split(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Split a table.
split(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Split a table.
split(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
split(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
split(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Split a table.
split(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
split(ServerName, HRegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
split(int, ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
Called when we need to convert a leaf node into a branch with 2 leaves.
split(RpcController, AdminProtos.AdminService.BlockingInterface, HRegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to split a region using admin protocol.
split - Variable in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
split(byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Split passed range.
split(byte[], byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Split passed range.
split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
 
split(int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
 
split(byte[], byte[], int, boolean) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
 
split(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
Split a pre-existing region into 2 regions.
split(int) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
Split an entire table.
split(byte[], byte[], int, boolean) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
Some MapReduce jobs may want to run multiple mappers per region, this is intended for such usecase.
split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
split(int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
split(byte[], byte[], int, boolean) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
split(Path, Path, Path, FileSystem, Configuration, WALFactory) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
 
split2(BigInteger, BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
Divide 2 numbers in half (for split algorithm)
SPLIT_ALGO - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
For MapReduce jobs running multiple mappers per region, determines what split algorithm we should be using to find split points for scanners.
SPLIT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SPLIT_LOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used to construct the name of the splitlog directory for a region server
SPLIT_PARTS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
The target count of new stripes to produce when splitting a stripe.
SPLIT_PLAN_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
SPLIT_PLAN_COUNT_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
SPLIT_POLICY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
SPLIT_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SPLIT_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SPLIT_REQUEST_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SPLIT_REQUEST_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SPLIT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
 
SPLIT_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
 
SPLIT_SKIP_ERRORS_DEFAULT - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
By default we retry errors in splitting, rather than skipping.
SPLIT_SUCCESS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SPLIT_SUCCESS_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SPLIT_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
SPLIT_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
SPLIT_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
 
SPLIT_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
 
SPLIT_TRANSACTION_IMPL_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
 
SPLIT_WRITER_CREATION_BOUNDED - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
 
SPLITA_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The lower-half split region column qualifier
SPLITB_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The upper-half split region column qualifier
splitCell - Variable in class org.apache.hadoop.hbase.io.HalfStoreFileReader
 
splitKerberosName(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
Splitting fully qualified Kerberos name into parts
splitkey - Variable in class org.apache.hadoop.hbase.io.HalfStoreFileReader
 
splitLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
splitLog(Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
splitLog(Set<ServerName>, PathFilter) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
This method is the base split method that splits WAL files matching a filter.
SplitLogCounters - Class in org.apache.hadoop.hbase
Counters kept by the distributed WAL split log process.
SplitLogCounters() - Constructor for class org.apache.hadoop.hbase.SplitLogCounters
 
splitLogDistributed(Path) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
 
splitLogDistributed(List<Path>) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
The caller will block until all the log files of the given region server have been processed - successfully split or an error is encountered - by an available worker region server.
splitLogDistributed(Set<ServerName>, List<Path>, PathFilter) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
The caller will block until all the hbase:meta log files of the given region server have been processed - successfully split or an error is encountered - by an available worker region server.
splitLogFile(Path, FileStatus, FileSystem, Configuration, CancelableProgressable, LastSequenceId, CoordinatedStateManager, ZooKeeperProtos.SplitLogTask.RecoveryMode, WALFactory) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
Splits a WAL file into region's recovered-edits directory.
SplitLogManager - Class in org.apache.hadoop.hbase.master
Distributes the task of log splitting to the available region servers.
SplitLogManager(Server, Configuration, Stoppable, MasterServices, ServerName) - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager
Its OK to construct this object even when region-servers are not online.
SplitLogManager.ResubmitDirective - Enum in org.apache.hadoop.hbase.master
 
SplitLogManager.Task - Class in org.apache.hadoop.hbase.master
in memory state of an active task.
SplitLogManager.Task() - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
SplitLogManager.TaskBatch - Class in org.apache.hadoop.hbase.master
Keeps track of the batch of tasks submitted together by a caller in splitLogDistributed().
SplitLogManager.TaskBatch() - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
 
SplitLogManager.TerminationStatus - Enum in org.apache.hadoop.hbase.master
 
SplitLogManagerCoordination - Interface in org.apache.hadoop.hbase.coordination
Coordination for SplitLogManager.
splitLogManagerCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
SplitLogManagerCoordination.SplitLogManagerDetails - Class in org.apache.hadoop.hbase.coordination
Detail class that shares data between coordination and split log manager
SplitLogManagerCoordination.SplitLogManagerDetails(ConcurrentMap<String, SplitLogManager.Task>, MasterServices, Set<String>, ServerName) - Constructor for class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
 
SplitLogTask - Class in org.apache.hadoop.hbase
State of a WAL log split during distributed splitting.
SplitLogTask.Done - Class in org.apache.hadoop.hbase
 
SplitLogTask.Done(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Done
 
SplitLogTask.Err - Class in org.apache.hadoop.hbase
 
SplitLogTask.Err(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Err
 
SplitLogTask.Owned - Class in org.apache.hadoop.hbase
 
SplitLogTask.Owned(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Owned
 
SplitLogTask.Resigned - Class in org.apache.hadoop.hbase
 
SplitLogTask.Resigned(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Resigned
 
SplitLogTask.Unassigned - Class in org.apache.hadoop.hbase
 
SplitLogTask.Unassigned(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Unassigned
 
SplitLogWorker - Class in org.apache.hadoop.hbase.regionserver
This worker is spawned in every regionserver, including master.
SplitLogWorker(Server, Configuration, RegionServerServices, SplitLogWorker.TaskExecutor) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
 
SplitLogWorker(Server, Configuration, RegionServerServices, LastSequenceId, WALFactory) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
 
SplitLogWorker.TaskExecutor - Interface in org.apache.hadoop.hbase.regionserver
Objects implementing this interface actually do the task that has been acquired by a SplitLogWorker.
SplitLogWorker.TaskExecutor.Status - Enum in org.apache.hadoop.hbase.regionserver
 
SplitLogWorkerCoordination - Interface in org.apache.hadoop.hbase.coordination
Coordinated operations for SplitLogWorker and WALSplitterHandler Important methods for SplitLogWorker:
SplitLogWorkerCoordination.isReady() called from SplitLogWorker.run() to check whether the coordination is ready to supply the tasks
SplitLogWorkerCoordination.taskLoop() loop for new tasks until the worker is stopped
SplitLogWorkerCoordination.isStop() a flag indicates whether worker should finish
SplitLogWorkerCoordination.registerListener() called from SplitLogWorker.run() and could register listener for external changes in coordination (if required)
SplitLogWorkerCoordination.endTask(SplitLogTask, AtomicLong, SplitTaskDetails) notify coordination engine that
splitLogWorkerCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
SplitLogWorkerCoordination.SplitTaskDetails - Interface in org.apache.hadoop.hbase.coordination
Interface for log-split tasks Used to carry implementation details in encapsulated way through Handlers to the coordination API.
splitLogZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
splitMetaLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
Specialized method to handle the splitting for meta WAL
splitMetaLog(Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
Specialized method to handle the splitting for meta WAL
SplitNormalizationPlan - Class in org.apache.hadoop.hbase.master.normalizer
Normalization plan to split region.
SplitNormalizationPlan(HRegionInfo, byte[]) - Constructor for class org.apache.hadoop.hbase.master.normalizer.SplitNormalizationPlan
 
SplitOrMergeTracker - Class in org.apache.hadoop.hbase.zookeeper
Tracks the switch of split and merge states in ZK
SplitOrMergeTracker(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.SplitOrMergeTracker
 
splitRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Split an individual region.
splitRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Split an individual region.
splitRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Split an individual region.
splitRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Split an individual region.
splitRegion(Connection, HRegionInfo, HRegionInfo, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Splits the region into two in an atomic operation.
splitRegion(RpcController, AdminProtos.SplitRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Split a region on the region server.
splits - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
splitStoreFile(LoadIncrementalHFiles.LoadQueueItem, Table, byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
SPLITTING_EXT - Static variable in class org.apache.hadoop.hbase.wal.DefaultWALProvider
File Extension used while splitting an WAL into regions (HBASE-2312)
SplitTransaction - Interface in org.apache.hadoop.hbase.regionserver
Executes region split as a "transaction".
SplitTransaction.JournalEntry - Interface in org.apache.hadoop.hbase.regionserver
Split transaction journal entry
SplitTransaction.SplitTransactionPhase - Enum in org.apache.hadoop.hbase.regionserver
Each enum is a step in the split transaction.
SplitTransaction.TransactionListener - Interface in org.apache.hadoop.hbase.regionserver
Split transaction listener
SplitTransactionCoordination - Interface in org.apache.hadoop.hbase.coordination
Coordination operations for split transaction.
splitTransactionCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
SplitTransactionCoordination.SplitTransactionDetails - Interface in org.apache.hadoop.hbase.coordination
Dummy interface for split transaction details.
SplitTransactionFactory - Class in org.apache.hadoop.hbase.regionserver
A factory for creating SplitTransactions, which execute region split as a "transaction".
SplitTransactionFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
 
SplitTransactionImpl - Class in org.apache.hadoop.hbase.regionserver
 
SplitTransactionImpl(Region, byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
Constructor
SplitTransactionImpl.JournalEntryImpl - Class in org.apache.hadoop.hbase.regionserver
 
SplitTransactionImpl.JournalEntryImpl(SplitTransaction.SplitTransactionPhase) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
 
SplitTransactionImpl.JournalEntryImpl(SplitTransaction.SplitTransactionPhase, long) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
 
SPNEGO_FILTER - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
src - Variable in class org.apache.hadoop.hbase.types.StructIterator
 
srcChecksum - Static variable in class org.apache.hadoop.hbase.Version
 
SslRMIClientSocketFactorySecure - Class in org.apache.hadoop.hbase
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
SslRMIClientSocketFactorySecure() - Constructor for class org.apache.hadoop.hbase.SslRMIClientSocketFactorySecure
 
SslRMIServerSocketFactorySecure - Class in org.apache.hadoop.hbase
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
SslRMIServerSocketFactorySecure() - Constructor for class org.apache.hadoop.hbase.SslRMIServerSocketFactorySecure
 
SslSelectChannelConnectorSecure - Class in org.apache.hadoop.hbase.jetty
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
SslSelectChannelConnectorSecure() - Constructor for class org.apache.hadoop.hbase.jetty.SslSelectChannelConnectorSecure
 
SslSocketConnectorSecure - Class in org.apache.hadoop.hbase.http
This subclass of the Jetty SslSocketConnector exists solely to control the TLS protocol versions allowed.
SslSocketConnectorSecure() - Constructor for class org.apache.hadoop.hbase.http.SslSocketConnectorSecure
 
stampSet - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
standardizeZKQuorumServerString(String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
Standardize the ZK quorum string: make it a "server:clientport" list, separated by ','
standardSchemeReadValue(TProtocol, TField) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
standardSchemeWriteValue(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
start() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
Start monitoring for archive updates
start(RootDoc) - Static method in class org.apache.hadoop.hbase.classification.tools.ExcludePrivateAnnotationsStandardDoclet
 
start(RootDoc) - Static method in class org.apache.hadoop.hbase.classification.tools.IncludePublicAnnotationsStandardDoclet
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.constraint.ConstraintProcessor
 
start() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
Starts service.
start() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
Stores a reference to the coprocessor environment provided by the RegionCoprocessorHost from the region where this coprocessor is loaded.
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
Stores a reference to the coprocessor environment provided by the RegionCoprocessorHost from the region where this coprocessor is loaded.
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.RefreshHFilesEndpoint
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
Stores a reference to the coprocessor environment provided by the RegionCoprocessorHost from the region where this coprocessor is loaded.
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
Stores a reference to the coprocessor environment provided by the RegionCoprocessorHost from the region where this coprocessor is loaded.
start(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
 
start() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
Start a timer to fail a process if it takes longer than the expected time to complete.
start() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
 
start() - Method in class org.apache.hadoop.hbase.http.HttpServer
Start the server.
start() - Method in class org.apache.hadoop.hbase.http.InfoServer
 
start() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
start(int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
start() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Prepares for request serving.
start() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
Starts the service.
start() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
 
start() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.JMXListener
 
START - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
Deprecated.
start() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
start() - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
 
start() - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
Start accepting flush table requests.
start(ProcedureCoordinator) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
Initialize and start threads necessary to connect an implementation's rpc mechanisms.
start(String, ProcedureMember) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
Initialize and start any threads or connections the member needs.
start() - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
Start accepting procedure requests.
start() - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
 
start(ProcedureCoordinator) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
Start monitoring znodes in ZK - subclass hook to start monitoring znodes they are about.
start(String, ProcedureMember) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
 
start(int, boolean) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Start the procedure executor.
start(int) - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
 
start(int) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
Start/Open the procedure store
start(int) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
start() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
start() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
 
start(RpcScheduler) - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
 
start(ChoreService) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
start() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
Start accepting snapshot requests.
start() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
start the SplitLogWorker thread
start(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
 
start(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
start(String) - Method in interface org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
Start the throughput controller.
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
start() - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
 
start() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
 
start() - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
 
start() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
 
start() - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController.VisibilityReplication
 
start() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
start() - Method in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
 
start(I, Hbase.append_args, AsyncMethodCallback<List<TCell>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.append
 
start(I, Hbase.atomicIncrement_args, AsyncMethodCallback<Long>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.atomicIncrement
 
start(I, Hbase.checkAndPut_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.checkAndPut
 
start(I, Hbase.compact_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.compact
 
start(I, Hbase.createTable_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.createTable
 
start(I, Hbase.deleteAll_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAll
 
start(I, Hbase.deleteAllRow_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllRow
 
start(I, Hbase.deleteAllRowTs_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllRowTs
 
start(I, Hbase.deleteAllTs_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteAllTs
 
start(I, Hbase.deleteTable_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.deleteTable
 
start(I, Hbase.disableTable_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.disableTable
 
start(I, Hbase.enableTable_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.enableTable
 
start(I, Hbase.get_args, AsyncMethodCallback<List<TCell>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.get
 
start(I, Hbase.getColumnDescriptors_args, AsyncMethodCallback<Map<ByteBuffer, ColumnDescriptor>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getColumnDescriptors
 
start(I, Hbase.getRegionInfo_args, AsyncMethodCallback<TRegionInfo>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRegionInfo
 
start(I, Hbase.getRow_args, AsyncMethodCallback<List<TRowResult>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRow
 
start(I, Hbase.getRowOrBefore_args, AsyncMethodCallback<List<TCell>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowOrBefore
 
start(I, Hbase.getRows_args, AsyncMethodCallback<List<TRowResult>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRows
 
start(I, Hbase.getRowsTs_args, AsyncMethodCallback<List<TRowResult>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsTs
 
start(I, Hbase.getRowsWithColumns_args, AsyncMethodCallback<List<TRowResult>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsWithColumns
 
start(I, Hbase.getRowsWithColumnsTs_args, AsyncMethodCallback<List<TRowResult>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowsWithColumnsTs
 
start(I, Hbase.getRowTs_args, AsyncMethodCallback<List<TRowResult>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowTs
 
start(I, Hbase.getRowWithColumns_args, AsyncMethodCallback<List<TRowResult>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowWithColumns
 
start(I, Hbase.getRowWithColumnsTs_args, AsyncMethodCallback<List<TRowResult>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getRowWithColumnsTs
 
start(I, Hbase.getTableNames_args, AsyncMethodCallback<List<ByteBuffer>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getTableNames
 
start(I, Hbase.getTableRegions_args, AsyncMethodCallback<List<TRegionInfo>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getTableRegions
 
start(I, Hbase.getVer_args, AsyncMethodCallback<List<TCell>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getVer
 
start(I, Hbase.getVerTs_args, AsyncMethodCallback<List<TCell>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.getVerTs
 
start(I, Hbase.increment_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.increment
 
start(I, Hbase.incrementRows_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.incrementRows
 
start(I, Hbase.isTableEnabled_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.isTableEnabled
 
start(I, Hbase.majorCompact_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.majorCompact
 
start(I, Hbase.mutateRow_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRow
 
start(I, Hbase.mutateRows_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRows
 
start(I, Hbase.mutateRowsTs_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRowsTs
 
start(I, Hbase.mutateRowTs_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.mutateRowTs
 
start(I, Hbase.scannerClose_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerClose
 
start(I, Hbase.scannerGet_args, AsyncMethodCallback<List<TRowResult>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerGet
 
start(I, Hbase.scannerGetList_args, AsyncMethodCallback<List<TRowResult>>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerGetList
 
start(I, Hbase.scannerOpen_args, AsyncMethodCallback<Integer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpen
 
start(I, Hbase.scannerOpenTs_args, AsyncMethodCallback<Integer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenTs
 
start(I, Hbase.scannerOpenWithPrefix_args, AsyncMethodCallback<Integer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithPrefix
 
start(I, Hbase.scannerOpenWithScan_args, AsyncMethodCallback<Integer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithScan
 
start(I, Hbase.scannerOpenWithStop_args, AsyncMethodCallback<Integer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithStop
 
start(I, Hbase.scannerOpenWithStopTs_args, AsyncMethodCallback<Integer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncProcessor.scannerOpenWithStopTs
 
start(I, THBaseService.append_args, AsyncMethodCallback<TResult>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.append
 
start(I, THBaseService.checkAndDelete_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndDelete
 
start(I, THBaseService.checkAndMutate_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndMutate
 
start(I, THBaseService.checkAndPut_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndPut
 
start(I, THBaseService.closeScanner_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.closeScanner
 
start(I, THBaseService.deleteMultiple_args, AsyncMethodCallback<List<TDelete>>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.deleteMultiple
 
start(I, THBaseService.deleteSingle_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.deleteSingle
 
start(I, THBaseService.exists_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.exists
 
start(I, THBaseService.get_args, AsyncMethodCallback<TResult>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.get
 
start(I, THBaseService.getAllRegionLocations_args, AsyncMethodCallback<List<THRegionLocation>>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getAllRegionLocations
 
start(I, THBaseService.getMultiple_args, AsyncMethodCallback<List<TResult>>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getMultiple
 
start(I, THBaseService.getRegionLocation_args, AsyncMethodCallback<THRegionLocation>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getRegionLocation
 
start(I, THBaseService.getScannerResults_args, AsyncMethodCallback<List<TResult>>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getScannerResults
 
start(I, THBaseService.getScannerRows_args, AsyncMethodCallback<List<TResult>>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getScannerRows
 
start(I, THBaseService.increment_args, AsyncMethodCallback<TResult>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.increment
 
start(I, THBaseService.mutateRow_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.mutateRow
 
start(I, THBaseService.openScanner_args, AsyncMethodCallback<Integer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.openScanner
 
start(I, THBaseService.put_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.put
 
start(I, THBaseService.putMultiple_args, AsyncMethodCallback<Void>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.putMultiple
 
start() - Method in class org.apache.hadoop.hbase.util.HasThread
 
start() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
 
start() - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
 
start() - Method in class org.apache.hadoop.hbase.zookeeper.DrainingServerTracker
Starts the tracking of draining RegionServers.
start() - Method in class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
Starts the tracking of whether master is in Maintenance Mode.
start() - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
Starts the tracking of online RegionServers.
start() - Method in class org.apache.hadoop.hbase.zookeeper.SplitOrMergeTracker
 
start() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
 
start() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Starts the tracking of the node in ZooKeeper.
START_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
Deprecated.
 
START_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
startAndPrefix - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
the prefix (and thus start row) of the keys you want
startAndWait() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
Deprecated.
 
startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Starts encoding for a block of KeyValues.
startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
 
startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Starts encoding for a block of KeyValues.
startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
startBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
 
startBold() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
startCacheFlush(byte[], Set<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
startCacheFlush(byte[], Set<byte[]>) - Method in interface org.apache.hadoop.hbase.wal.WAL
WAL keeps track of the sequence numbers that are as yet not flushed im memstores in order to be able to do accounting to figure which WALs can be let go.
startCancel() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
startCancel() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
startCancel() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
startcode - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
This servers startcode.
startCode - Variable in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
STARTCODE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
STARTCODE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
The startcode column qualifier
STARTCODE_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The startcode column qualifier
startConnectorServer(int, int) - Method in class org.apache.hadoop.hbase.JMXListener
 
startExecutorService(String, int) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
Start an executor service with a given name.
startExecutorService(ExecutorType, int) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
 
startHandlers(int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
startHandlers(String, int, List<BlockingQueue<CallRunner>>, int, int, int, AtomicInteger) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
Start up our handlers.
startHandlers(int) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
startHighlight() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
 
startHighlight() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
startKey - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
Key to seek to in memstore and StoreFiles
startKey - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
startKey - Variable in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
STARTKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
startMillis() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionWindow
Inclusive lower bound
startOffset - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
startOperation(long, long, Stoppable) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
Starts the operation if operation with such nonce has not already succeeded.
startPeerConfigTracker(ZooKeeperWatcher, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
start a table-cfs tracker to listen the (table, cf-list) map change
startProcedure(ForeignExceptionDispatcher, String, byte[], List<String>) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
Kick off the named procedure Currently only one procedure with the same type and name is allowed to run at a time.
startRegionMergeTransaction(HRegionInfo, ServerName, HRegionInfo, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
Start the region merge transaction
startRegionMergeTransaction(HRegionInfo, ServerName, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
Creates a new ephemeral node in the PENDING_MERGE state for the merged region.
startRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
startRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
startRegionOperation() - Method in interface org.apache.hadoop.hbase.regionserver.Region
This method needs to be called before any public call that reads or modifies data.
startRegionOperation(Region.Operation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
This method needs to be called before any public call that reads or modifies data.
startReplicationService() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
Start replication services.
startReplicationService() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
If replication is enabled and this cluster is a master, it starts
startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
Starting row in table to scan.
startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
Starting row in table to scan.
startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
Starting row in table to scan.
startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
Starting row in table to scan.
startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
 
startRow - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
STARTROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
startSplitTransaction(HRegion, ServerName, HRegionInfo, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
init coordination for split transaction
startSplitTransaction(HRegion, ServerName, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
Creates a new ephemeral node in the PENDING_SPLIT state for the specified region.
startStateTracker(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
start a state tracker to check whether this peer is enabled or not
startsWith(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Return true if the byte array on the right is a prefix of the byte array on the left.
startTime - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
STARTTIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
startup() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
Initialize the environment
startup() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Start the cluster.
startup() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.ReplicationSourceShipperThread
 
startup() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
startup() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
Start the replication
startup(List<JVMClusterUtil.MasterThread>, List<JVMClusterUtil.RegionServerThread>) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
Start the cluster.
startup(File) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
startup(File, int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
startWriterThreads() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
Called by the constructor to start the writer threads.
startWriterThreads() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
Start the threads that will pump data from the entryBuffers to the output files.
state - Variable in enum org.apache.hadoop.hbase.security.SaslStatus
 
state() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
STATE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
 
STATE_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The state column qualifier
StateDumpServlet - Class in org.apache.hadoop.hbase.monitoring
 
StateDumpServlet() - Constructor for class org.apache.hadoop.hbase.monitoring.StateDumpServlet
 
statelessUncompressor - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
 
StateMachineProcedure<TEnvironment,TState> - Class in org.apache.hadoop.hbase.procedure2
Procedure described by a series of steps.
StateMachineProcedure() - Constructor for class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
 
StateMachineProcedure.Flow - Enum in org.apache.hadoop.hbase.procedure2
 
STATIC_BLOOM_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
STATIC_BLOOM_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
STATIC_INDEX_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
STATIC_INDEX_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
StaticUserWebFilter - Class in org.apache.hadoop.hbase.http.lib
Provides a servlet filter that pretends to authenticate a fake user (Dr.Who) so that the web UI is usable for a secure cluster without authentication.
StaticUserWebFilter() - Constructor for class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter
 
StaticUserWebFilter.StaticUserFilter - Class in org.apache.hadoop.hbase.http.lib
 
StaticUserWebFilter.StaticUserFilter() - Constructor for class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
 
StatisticTrackable - Interface in org.apache.hadoop.hbase.client
Parent interface for an object to get updates about per-region statistics.
STATS_RECORD_SEP - Static variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Record separator for the Bloom filter statistics human-readable string
status - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
status - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
STATUS_MULTICAST_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
IP to use for the multicast status messages between the master and the clients.
STATUS_MULTICAST_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
The address to use for binding the local socket for receiving multicast.
STATUS_MULTICAST_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
The port to use for the multicast messages.
STATUS_PUBLISH_PERIOD - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
The minimum time between two status messages, in milliseconds.
STATUS_PUBLISHED - Static variable in class org.apache.hadoop.hbase.HConstants
Setting to activate, or not, the publication of the status by the master.
STATUS_PUBLISHED_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
STATUS_PUBLISHER_CLASS - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
The implementation class used to publish the status.
std(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handle for calling the std method for a given cf-cq combination.
std(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handle for calling the std method for a given cf-cq combination.
std - Variable in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
 
StealJobQueue<T> - Class in org.apache.hadoop.hbase.util
This queue allows a ThreadPoolExecutor to steal jobs from another ThreadPoolExecutor.
StealJobQueue() - Constructor for class org.apache.hadoop.hbase.util.StealJobQueue
 
StealJobQueue(int, int) - Constructor for class org.apache.hadoop.hbase.util.StealJobQueue
 
stepDownAsLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
Removes the leader znode, if it is currently claimed by this instance.
SteppingSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
 
SteppingSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.SteppingSplitPolicy
 
STEPS_PER_REGION_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
stepsAfterPONR(Server, RegionServerServices, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
Deprecated.
stepsAfterPONR(Server, RegionServerServices, HRegion, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
 
stepsAfterPONR(Server, RegionServerServices, PairOfSameType<Region>) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
Deprecated.
stepsAfterPONR(Server, RegionServerServices, PairOfSameType<Region>, User) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
 
stepsBeforePONR(Server, RegionServerServices, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
 
stepsBeforePONR(Server, RegionServerServices, boolean) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
 
StochasticLoadBalancer - Class in org.apache.hadoop.hbase.master.balancer
This is a best effort load balancer.
StochasticLoadBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
The constructor that pass a MetricsStochasticBalancer to BaseLoadBalancer to replace its default MetricsBalancer
stop(String) - Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
 
stop() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
Stop this tracker and the passed zookeeper
stop() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
Stops service.
stop() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.RefreshHFilesEndpoint
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
 
stop(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
 
stop() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
 
stop() - Method in class org.apache.hadoop.hbase.http.HttpServer
stop the server
stop() - Method in class org.apache.hadoop.hbase.http.InfoServer
 
stop() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
stop() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
stop() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Stops serving new requests.
stop() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
Stops the service.
stop() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
 
stop() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.JMXListener
 
stop() - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
 
stop() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
stop(String) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
stop(String) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
 
stop(String) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
 
stop() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
stop() - Method in class org.apache.hadoop.hbase.master.ServerManager
Stop the ServerManager.
stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
 
stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
 
stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
stop() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
 
stop() - Method in class org.apache.hadoop.hbase.metrics.impl.GlobalMetricRegistriesAdapter
 
stop(String) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
 
stop(boolean) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
Close this and all running tasks
stop(String) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
 
stop(boolean) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
Close this and all running procedure tasks
stop(boolean) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
 
stop() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
stop(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
 
stop(boolean) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
Stop/Close the procedure store
stop(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
stop() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
stop(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
 
stop() - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
 
stop() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
stop(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionsCleaner
 
stop(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
stop(String, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Stops the regionserver.
stop(boolean) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
Close this and all running snapshot tasks
stop() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
stop the SplitLogWorker thread
stop(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
 
stop(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
stop(String) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
 
stop(String) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
 
stop() - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
stop(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
 
stop() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController.VisibilityReplication
 
stop() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
stop(String) - Method in interface org.apache.hadoop.hbase.Stoppable
Stop this service.
stop() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
 
stop() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
 
stop() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
 
stop() - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Stop working.
stop() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
stop() - Static method in class org.apache.hadoop.metrics2.impl.JmxCacheBuster
Stops the clearing of JMX metrics and restarting the Hadoop metrics system.
stop() - Method in class org.apache.hadoop.metrics2.lib.MetricsExecutorImpl
 
stop() - Method in interface org.apache.hadoop.metrics2.MetricsExecutor
 
STOP_TIMEOUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
Time to wait for server to stop gracefully
stopAndDrainOps() - Method in class org.apache.hadoop.hbase.util.DrainBarrier
Blocks new operations from starting, waits for the current ones to drain.
stopAndDrainOpsOnce() - Method in class org.apache.hadoop.hbase.util.DrainBarrier
Blocks new operations from starting, waits for the current ones to drain.
stopAndWait() - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
 
stopAndWait() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
stopBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
 
stopBold() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
stopConnectorServer() - Method in class org.apache.hadoop.hbase.JMXListener
 
stopHighlight() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
 
stopHighlight() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
stopMaster() - Method in interface org.apache.hadoop.hbase.client.Admin
Shuts down the current HBase master only.
stopMaster() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Shuts down the current HBase master only.
stopMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
 
stopMaster(RpcController, MasterProtos.StopMasterRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
Stoppable - Interface in org.apache.hadoop.hbase
Implementers are Stoppable.
StoppedRpcClientException - Exception in org.apache.hadoop.hbase.ipc
 
StoppedRpcClientException() - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
 
StoppedRpcClientException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
 
stopProcessingTasks() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
called when Coordination should stop processing tasks and exit
stopProcessingTasks() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
 
stopRegionServer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Stop the designated regionserver
stopRegionServer(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Stop the designated regionserver
stopReplicationService() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
Stops replication service.
stopReplicationService() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
Stops replication service.
stopReplicationSinkServices() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
stop the thread pool executor.
stopRequested - Variable in class org.apache.hadoop.hbase.regionserver.Leases
 
stopRow - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
stopRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
row to stop scanning on.
stopRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
row to stop scanning on.
stopRow - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
 
stopRow - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
stopServer(RpcController, AdminProtos.StopServerRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Stop the region server.
stopServiceThreads() - Method in class org.apache.hadoop.hbase.master.HMaster
 
stopServiceThreads() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Wait on all threads to finish.
stopTask() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
If the worker is doing a task i.e.
StorageClusterStatusMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus
StorageClusterStatusMessage.StorageClusterStatus.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus
StorageClusterStatusMessage.StorageClusterStatus.Node - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node
StorageClusterStatusMessage.StorageClusterStatus.Node.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node
StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus.Region - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region
StorageClusterStatusMessage.StorageClusterStatus.Region.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region
StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatusOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
StorageClusterStatusModel - Class in org.apache.hadoop.hbase.rest.model
Representation of the status of a storage cluster:
StorageClusterStatusModel() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
Default constructor
StorageClusterStatusModel.Node - Class in org.apache.hadoop.hbase.rest.model
Represents a region server.
StorageClusterStatusModel.Node() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
Default constructor
StorageClusterStatusModel.Node(String, long) - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
Constructor
StorageClusterStatusModel.Node.Region - Class in org.apache.hadoop.hbase.rest.model
Represents a region hosted on a region server.
StorageClusterStatusModel.Node.Region() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
Default constructor
StorageClusterStatusModel.Node.Region(byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
Constructor
StorageClusterStatusModel.Node.Region(byte[], int, int, int, int, int, long, long, int, int, int, long, long) - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
Constructor
StorageClusterStatusResource - Class in org.apache.hadoop.hbase.rest
 
StorageClusterStatusResource() - Constructor for class org.apache.hadoop.hbase.rest.StorageClusterStatusResource
Constructor
StorageClusterVersionModel - Class in org.apache.hadoop.hbase.rest.model
Simple representation of the version of the storage cluster
StorageClusterVersionModel() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
 
StorageClusterVersionResource - Class in org.apache.hadoop.hbase.rest
 
StorageClusterVersionResource() - Constructor for class org.apache.hadoop.hbase.rest.StorageClusterVersionResource
Constructor
store - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
store - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
Store - Interface in org.apache.hadoop.hbase.regionserver
Interface for objects that hold a column family in a Region.
store - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
store(ByteRange) - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
STORE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
STORE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
STORE_ENGINE_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
The name of the configuration parameter that specifies the class of a store engine that is used to manage and compact HBase store files.
STORE_FILE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
STORE_FILE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
STORE_WAL_SYNC_STATS_COUNT - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
storeConfigInfo - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
 
StoreConfigInformation - Interface in org.apache.hadoop.hbase.regionserver
A more restricted interface for HStore.
StoreEngine<SF extends org.apache.hadoop.hbase.regionserver.StoreFlusher,CP extends CompactionPolicy,C extends Compactor,SFM extends StoreFileManager> - Class in org.apache.hadoop.hbase.regionserver
StoreEngine is a factory that can create the objects necessary for HStore to operate.
StoreEngine() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreEngine
 
StoreFile - Class in org.apache.hadoop.hbase.regionserver
A Store data file.
StoreFile(FileSystem, Path, Configuration, CacheConfig, BloomType) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile
Constructor, loads a reader and it's indices, etc.
StoreFile(FileSystem, StoreFileInfo, Configuration, CacheConfig, BloomType) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile
Constructor, loads a reader and it's indices, etc.
StoreFile(StoreFile) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile
Clone
storeFile(HRegionInfo, String, SnapshotProtos.SnapshotRegionManifest.StoreFile) - Method in interface org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil.StoreFileVisitor
 
storeFile(String, String, String) - Method in interface org.apache.hadoop.hbase.util.FSVisitor.StoreFileVisitor
 
StoreFile.Comparators - Class in org.apache.hadoop.hbase.regionserver
Useful comparators for comparing StoreFiles.
StoreFile.Comparators() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.Comparators
 
StoreFile.Reader - Class in org.apache.hadoop.hbase.regionserver
Reader for a StoreFile.
StoreFile.Reader(FileSystem, Path, CacheConfig, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
StoreFile.Reader(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
StoreFile.Writer - Class in org.apache.hadoop.hbase.regionserver
A StoreFile writer.
StoreFile.WriterBuilder - Class in org.apache.hadoop.hbase.regionserver
 
StoreFile.WriterBuilder(Configuration, CacheConfig, FileSystem) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
STOREFILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
STOREFILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
STOREFILE_INDEX_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
STOREFILE_INDEX_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
storeFile_jsp - Class in org.apache.hadoop.hbase.generated.regionserver
 
storeFile_jsp() - Constructor for class org.apache.hadoop.hbase.generated.regionserver.storeFile_jsp
 
STOREFILE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
STOREFILE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
STOREFILEINDEXSIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
StoreFileInfo - Class in org.apache.hadoop.hbase.regionserver
Describe a StoreFile (hfile, reference, link)
StoreFileInfo(Configuration, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Create a Store File Info
StoreFileInfo(Configuration, FileSystem, FileStatus) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Create a Store File Info
StoreFileInfo(Configuration, FileSystem, FileStatus, HFileLink) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Create a Store File Info from an HFileLink
StoreFileInfo(Configuration, FileSystem, FileStatus, Reference) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Create a Store File Info from an HFileLink
storeFileManager - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
StoreFileManager - Interface in org.apache.hadoop.hbase.regionserver
Manages the store files and basic metadata about that that determines the logical structure (e.g.
StorefileRefresherChore - Class in org.apache.hadoop.hbase.regionserver
A chore for refreshing the store files for secondary regions hosted in the region server.
StorefileRefresherChore(int, boolean, HRegionServer, Stoppable) - Constructor for class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
 
STOREFILES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
StoreFileScanner - Class in org.apache.hadoop.hbase.regionserver
KeyValueScanner adaptor over the Reader.
StoreFileScanner(StoreFile.Reader, HFileScanner, boolean, boolean, long, long, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileScanner
Implements a KeyValueScanner on top of the specified HFileScanner
STOREFILESIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
storeFlusher - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
storeLimit - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
storeOffset - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
stores - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
STORES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
StoreScanner - Class in org.apache.hadoop.hbase.regionserver
Scanner scans both the memstore and the Store.
StoreScanner(Store, Scan, ScanInfo, NavigableSet<byte[]>, long, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
An internal constructor.
StoreScanner(Store, ScanInfo, Scan, NavigableSet<byte[]>, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
Opens a scanner across memstore, snapshot, and all StoreFiles.
StoreScanner(Store, ScanInfo, Scan, List<? extends KeyValueScanner>, ScanType, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
Used for compactions.
StoreScanner(Store, ScanInfo, Scan, List<? extends KeyValueScanner>, long, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
Used for compactions that drop deletes from a limited range of rows.
StoreScanner(Scan, ScanInfo, ScanType, NavigableSet<byte[]>, List<KeyValueScanner>, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
 
STORESCANNER_PARALLEL_SEEK_ENABLE - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
StoreUtils - Class in org.apache.hadoop.hbase.regionserver
Utility functions for region server storage layer.
StoreUtils() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreUtils
 
StreamUtils - Class in org.apache.hadoop.hbase.io.util
 
StreamUtils() - Constructor for class org.apache.hadoop.hbase.io.util.StreamUtils
 
STRING - Static variable in class org.apache.hadoop.hbase.util.ClassSize
String overhead
STRING_VIS_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
 
stringify(Class[]) - Static method in class org.apache.hadoop.hbase.util.Classes
 
stringifyFilter(Filter) - Static method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
Strings - Class in org.apache.hadoop.hbase.util
Utility for Strings.
Strings() - Constructor for class org.apache.hadoop.hbase.util.Strings
 
StringUtils - Class in org.apache.hadoop.hbase.procedure2.util
 
STRIPE_END_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
STRIPE_START_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
The file metadata fields that contain the stripe information.
StripeCompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
Stripe store implementation of compaction policy.
StripeCompactionPolicy(Configuration, StoreConfigInformation, StripeStoreConfig) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
 
StripeCompactionPolicy.StripeCompactionRequest - Class in org.apache.hadoop.hbase.regionserver.compactions
Stripe compaction request wrapper.
StripeCompactionPolicy.StripeCompactionRequest(CompactionRequest) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
 
StripeCompactionPolicy.StripeInformationProvider - Interface in org.apache.hadoop.hbase.regionserver.compactions
The information about stripes that the policy needs to do its stuff
StripeCompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
Query matcher for stripe compaction if range drop deletes is used.
StripeCompactionScanQueryMatcher(ScanInfo, DeleteTracker, long, long, long, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher
 
StripeCompactor - Class in org.apache.hadoop.hbase.regionserver.compactions
This is the placeholder for stripe compactor.
StripeCompactor(Configuration, Store) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
 
StripeMultiFileWriter - Class in org.apache.hadoop.hbase.regionserver
Base class for cell sink that separates the provided cells into multiple files for stripe compaction.
StripeMultiFileWriter(KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
StripeMultiFileWriter.BoundaryMultiWriter - Class in org.apache.hadoop.hbase.regionserver
MultiWriter that separates the cells based on fixed row-key boundaries.
StripeMultiFileWriter.BoundaryMultiWriter(KeyValue.KVComparator, List<byte[]>, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
 
StripeMultiFileWriter.SizeMultiWriter - Class in org.apache.hadoop.hbase.regionserver
MultiWriter that separates the cells based on target cell number per file and file count.
StripeMultiFileWriter.SizeMultiWriter(KeyValue.KVComparator, int, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
 
StripeStoreConfig - Class in org.apache.hadoop.hbase.regionserver
Configuration class for stripe store and compactions.
StripeStoreConfig(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
 
StripeStoreEngine - Class in org.apache.hadoop.hbase.regionserver
The storage engine that implements the stripe-based store/compaction scheme.
StripeStoreEngine() - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
 
StripeStoreFileManager - Class in org.apache.hadoop.hbase.regionserver
Stripe implementation of StoreFileManager.
StripeStoreFileManager(KeyValue.KVComparator, Configuration, StripeStoreConfig) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
StripeStoreFlusher - Class in org.apache.hadoop.hbase.regionserver
Stripe implementation of StoreFlusher.
StripeStoreFlusher(Configuration, Store, StripeCompactionPolicy, StripeStoreFileManager) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher
 
StripeStoreFlusher.BoundaryStripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
Stripe flush request wrapper based on boundaries.
StripeStoreFlusher.BoundaryStripeFlushRequest(KeyValue.KVComparator, List<byte[]>) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequest
 
StripeStoreFlusher.SizeStripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
Stripe flush request wrapper based on size.
StripeStoreFlusher.SizeStripeFlushRequest(KeyValue.KVComparator, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.SizeStripeFlushRequest
 
StripeStoreFlusher.StripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
Stripe flush request wrapper that writes a non-striped file.
StripeStoreFlusher.StripeFlushRequest(KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
 
strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
 
strToRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
 
strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
Struct - Class in org.apache.hadoop.hbase.types
Struct is a simple DataType for implementing "compound rowkey" and "compound qualifier" schema design strategies.
Struct(DataType[]) - Constructor for class org.apache.hadoop.hbase.types.Struct
Create a new Struct instance defined as the sequence of HDataTypes in memberTypes.
StructBuilder - Class in org.apache.hadoop.hbase.types
A helper for building Struct instances.
StructBuilder() - Constructor for class org.apache.hadoop.hbase.types.StructBuilder
Create an empty StructBuilder.
StructIterator - Class in org.apache.hadoop.hbase.types
An Iterator over encoded Struct members.
StructIterator(PositionedByteRange, DataType[]) - Constructor for class org.apache.hadoop.hbase.types.StructIterator
Construct StructIterator over the values encoded in src using the specified types definition.
stub - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
subFiltersIncludedCell - Variable in class org.apache.hadoop.hbase.filter.FilterListBase
For each sub-filter in filter list, we save a boolean flag to indicate that whether the return code of filterCell(c) for sub-filter is INCLUDE* (INCLUDE, INCLUDE_AND_NEXT_COL, INCLUDE_AND_SEEK_NEXT_ROW) case.
subList(int, int) - Method in class org.apache.hadoop.hbase.util.SortedList
 
subMap(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
subMap(K, K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
subMap(K, boolean, K, boolean) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
submit(RetryingCallable<V>, int, int) - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
submit(EventHandler) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
 
submit(Callable<V>) - Method in class org.apache.hadoop.hbase.util.BoundedCompletionService
 
submitAndWaitProcedure(ProcedureExecutor<MasterProcedureEnv>, Procedure) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
submitMaxNodeDepthCandidate(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
submitProcedure(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
 
submitProcedure(MasterProcedureUtil.NonceProcedureRunnable) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil
Helper used to deal with submitting procs with nonce.
submitProcedure(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Add a new root-procedure to the executor.
submitProcedure(Procedure, NonceKey) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Add a new root-procedure to the executor.
submitSubprocedure(Subprocedure) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
Submit an subprocedure for execution.
submitTask(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
 
submitTask(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
Subprocedure - Class in org.apache.hadoop.hbase.procedure
Distributed procedure member's Subprocedure.
Subprocedure(ProcedureMember, String, ForeignExceptionDispatcher, long, long) - Constructor for class org.apache.hadoop.hbase.procedure.Subprocedure
 
Subprocedure.SubprocedureImpl - Class in org.apache.hadoop.hbase.procedure
Empty Subprocedure for testing.
Subprocedure.SubprocedureImpl(ProcedureMember, String, ForeignExceptionDispatcher, long, long) - Constructor for class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
 
SubprocedureFactory - Interface in org.apache.hadoop.hbase.procedure
Task builder to build instances of a ProcedureMember's Subprocedures.
subset(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Returns a subset of the configuration properties, matching the given key prefix.
subSet(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
subSet(Cell, boolean, Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
subSet(E, E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
SubstringComparator - Class in org.apache.hadoop.hbase.filter
This comparator is for use with SingleColumnValueFilter, for filtering based on the value of a given column.
SubstringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.SubstringComparator
Constructor
substringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
SubstringType byte array
SUCCESS - Static variable in class org.apache.hadoop.hbase.regionserver.OperationStatus
Singleton for successful operations.
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
SUCCESSFUL_APPEND_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
SUCCESSFUL_DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
SUCCESSFUL_GET_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
SUCCESSFUL_INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
SUCCESSFUL_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
SUCCESSFUL_SCAN_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
sum(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It sums up the value returned from various regions.
sum(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
It sums up the value returned from various regions.
sum() - Method in class org.apache.hadoop.hbase.util.LongAdder
Returns the current sum.
summarize() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
Summary - Class in org.apache.hadoop.hbase.hbtop.screen.top
Represents the summary of the metrics.
Summary(String, String, String, int, int, int, int, int, double, long) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.Summary
 
sumOfMillisSecBetweenNexts - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
sum of milliseconds between sequential next calls
sumThenReset() - Method in class org.apache.hadoop.hbase.util.LongAdder
Equivalent in effect to LongAdder.sum() followed by LongAdder.reset().
SUPERUSER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.Superusers
Configuration key for superusers
Superusers - Class in org.apache.hadoop.hbase.security
Keeps lists of superusers and super groups loaded from HBase configuration, checks if certain user is regarded as superuser.
supportsAutoLoading() - Method in interface org.apache.hadoop.hbase.util.BloomFilter
 
supportsAutoLoading() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
supportsAutoLoading() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
 
suspend(MasterProcedureScheduler.ProcedureEvent) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
suspend(MasterProcedureScheduler.ProcedureEvent) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
sweep(String) - Method in interface org.apache.hadoop.hbase.util.LossyCounting.LossyCountingListener
 
SWITCH_TO_SIMPLE_AUTH - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
 
switchFieldDisplay() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
 
switchMode(Mode, List<RecordFilter>, boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
switchSortOrder() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
switchSortOrder() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
sync() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
No operation for the sync in the memory IO engine
sync() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
Sync the data to file after writing
sync() - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
Sync the data to IOEngine after writing
sync() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
sync(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
sync() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
sync() - Method in interface org.apache.hadoop.hbase.wal.WAL
Sync what we have in the WAL.
sync(long) - Method in interface org.apache.hadoop.hbase.wal.WAL
Sync the WAL if the txId was not already sync'd.
sync() - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
 
sync(String, AsyncCallback.VoidCallback, Object) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
sync(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Forces a synchronization of this ZooKeeper client connection.
SYNC_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
SYNC_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
SYNC_WAIT_MSEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
syncSlots(FSDataOutputStream, ByteSlot[], int, int) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
SyncTable - Class in org.apache.hadoop.hbase.mapreduce
 
SyncTable(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.SyncTable
 
SyncTable.SyncMapper - Class in org.apache.hadoop.hbase.mapreduce
 
SyncTable.SyncMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
 
SyncTable.SyncMapper.Counter - Enum in org.apache.hadoop.hbase.mapreduce
 
SYSTEM_CACHE_FLUSH_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
Default interval for System tables memstore flush
SYSTEM_LABEL - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
 
SYSTEM_NAMESPACE - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
SYSTEM_NAMESPACE_NAME - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
System namespace name.
SYSTEM_NAMESPACE_NAME_STR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
SYSTEMTABLE_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
SystemTableWALEntryFilter - Class in org.apache.hadoop.hbase.replication
Skips WAL edits for all System tables including META
SystemTableWALEntryFilter() - Constructor for class org.apache.hadoop.hbase.replication.SystemTableWALEntryFilter
 

T

TAB - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for tab
Table - Interface in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table.
table - Variable in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
table - Variable in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
the table to append the value on
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
to check in and delete from
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
to check in and delete from
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
to check in and put to
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
the table to delete from
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
the table to delete from
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
the table to check on
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
the table to check on
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
the table to get from
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
the table to get from
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
the table to get the Scanner for
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
the table to increment the value on
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
table to apply the mutations
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
the table to get the Scanner for
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
the table to put data in
table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
the table to put data in
TABLE_LOCK_ENABLE - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
Configuration key for enabling table-level locks for schema changes
TABLE_LOCK_EXPIRE_TIMEOUT - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
 
TABLE_MAX_ROWSIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Default max row size (1 Gb).
TABLE_MAX_ROWSIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Max size of single row for Get's or Scan's without in-row scanning flag set.
TABLE_MULTIPLEXER_FLUSH_PERIOD_MS - Static variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
 
TABLE_MULTIPLEXER_INIT_THREADS - Static variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
 
TABLE_MULTIPLEXER_MAX_RETRIES_IN_QUEUE - Static variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
 
TABLE_NAME - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
TABLE_READ_LOCK_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
Configuration key for time out for trying to acquire table locks
TABLE_ROW_TEXTKEY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Deprecated.
TABLE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
TABLE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
TABLE_WRITE_LOCK_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
Configuration key for time out for trying to acquire table locks
TableAuthManager - Class in org.apache.hadoop.hbase.security.access
Performs authorization checks for a given user's assigned permissions
tableCFsNodeName - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
The name of the znode that contains tableCFs
TableCFsUpdater - Class in org.apache.hadoop.hbase.replication.master
This class is used to upgrade TableCFs from HBase 1.0, 1.1, 1.2, 1.3 to HBase 1.4 or 2.x.
TableCFsUpdater(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.master.TableCFsUpdater
 
TableCfWALEntryFilter - Class in org.apache.hadoop.hbase.replication
 
TableCfWALEntryFilter(ReplicationPeer) - Constructor for class org.apache.hadoop.hbase.replication.TableCfWALEntryFilter
 
tableDeleted(TableName) - Method in class org.apache.hadoop.hbase.master.RegionStates
A table is deleted.
tableDeleted(TableName) - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
 
tableDeleted(TableName) - Method in class org.apache.hadoop.hbase.master.TableLockManager
Called after a table has been deleted, and after the table lock is released.
tableDescriptors - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
Go here to get table descriptors.
TableDescriptors - Interface in org.apache.hadoop.hbase
Get, remove and modify table descriptors.
tableDict - Variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
 
TableEventHandler - Class in org.apache.hadoop.hbase.master.handler
Base class for performing operations against tables.
TableEventHandler(EventType, TableName, Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
tableExists(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
 
tableExists(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
tableExists(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
tableExists(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
tableExists(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Checks if the specified table exists.
TableExistsException - Exception in org.apache.hadoop.hbase
Thrown when a table exists but should not.
TableExistsException() - Constructor for exception org.apache.hadoop.hbase.TableExistsException
 
TableExistsException(String) - Constructor for exception org.apache.hadoop.hbase.TableExistsException
 
TableExistsException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableExistsException
 
tableFieldsEqual(TablePermission) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
tableHasErrors(HBaseFsck.TableInfo) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
TableHFileArchiveTracker - Class in org.apache.hadoop.hbase.backup.example
Track HFile archiving state changes in ZooKeeper.
TableInfoMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableInfoMessage.TableInfo - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo
TableInfoMessage.TableInfo.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo
TableInfoMessage.TableInfo.Region - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region
TableInfoMessage.TableInfo.Region.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region
TableInfoMessage.TableInfo.RegionOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableInfoMessage.TableInfoOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableInfoMissingException - Exception in org.apache.hadoop.hbase
Failed to find .tableinfo file under the table directory.
TableInfoMissingException() - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
Failed to find .tableinfo file under the table directory.
TableInfoMissingException(String) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
 
TableInfoMissingException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
 
TableInfoMissingException(Throwable) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
 
TableInfoModel - Class in org.apache.hadoop.hbase.rest.model
Representation of a list of table regions.
TableInfoModel() - Constructor for class org.apache.hadoop.hbase.rest.model.TableInfoModel
Default constructor
TableInfoModel(String) - Constructor for class org.apache.hadoop.hbase.rest.model.TableInfoModel
Constructor
TableInputFormat - Class in org.apache.hadoop.hbase.mapred
Convert HBase tabular data into a format that is consumable by Map/Reduce.
TableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormat
 
TableInputFormat - Class in org.apache.hadoop.hbase.mapreduce
Convert HBase tabular data into a format that is consumable by Map/Reduce.
TableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableInputFormat
 
TableInputFormatBase - Class in org.apache.hadoop.hbase.mapred
A Base for TableInputFormats.
TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormatBase
 
TableInputFormatBase - Class in org.apache.hadoop.hbase.mapreduce
A base for TableInputFormats.
TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
 
TableIntegrityErrorHandler - Interface in org.apache.hadoop.hbase.util.hbck
This interface provides callbacks for handling particular table integrity invariant violations.
TableIntegrityErrorHandlerImpl - Class in org.apache.hadoop.hbase.util.hbck
Simple implementation of TableIntegrityErrorHandler.
TableIntegrityErrorHandlerImpl() - Constructor for class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
 
TableListMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableListMessage.TableList - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.TableList
TableListMessage.TableList.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.TableList
TableListMessage.TableListOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableListModel - Class in org.apache.hadoop.hbase.rest.model
Simple representation of a list of table names.
TableListModel() - Constructor for class org.apache.hadoop.hbase.rest.model.TableListModel
Default constructor
tableLock - Variable in class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
tableLock - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
TableLockChecker - Class in org.apache.hadoop.hbase.util.hbck
Utility to check and fix table locks.
TableLockChecker(ZooKeeperWatcher, HBaseFsck.ErrorReporter) - Constructor for class org.apache.hadoop.hbase.util.hbck.TableLockChecker
 
tableLockManager - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
TableLockManager - Class in org.apache.hadoop.hbase.master
A manager for distributed table level locks.
TableLockManager() - Constructor for class org.apache.hadoop.hbase.master.TableLockManager
 
tableLockManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
TableLockManager.NullTableLockManager - Class in org.apache.hadoop.hbase.master
A null implementation
TableLockManager.NullTableLockManager() - Constructor for class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
 
TableLockManager.TableLock - Interface in org.apache.hadoop.hbase.master
A distributed lock for a table.
tableLockZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
TableMap<K extends org.apache.hadoop.io.WritableComparable<? super K>,V> - Interface in org.apache.hadoop.hbase.mapred
Scan an HBase table to sort by a specified sort column.
TableMapper<KEYOUT,VALUEOUT> - Class in org.apache.hadoop.hbase.mapreduce
Extends the base Mapper class to add the required input key and value classes.
TableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableMapper
 
TableMapReduceUtil - Class in org.apache.hadoop.hbase.mapred
Utility for TableMap and TableReduce
TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
TableMapReduceUtil - Class in org.apache.hadoop.hbase.mapreduce
Utility for TableMapper and TableReducer
TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
 
TableModel - Class in org.apache.hadoop.hbase.rest.model
Simple representation of a table name.
TableModel() - Constructor for class org.apache.hadoop.hbase.rest.model.TableModel
Default constructor
TableModel(String) - Constructor for class org.apache.hadoop.hbase.rest.model.TableModel
Constructor
TableModeStrategy - Class in org.apache.hadoop.hbase.hbtop.mode
Implementation for ModeStrategy for Table Mode.
tableName - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
tableName - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
 
tableName - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
tableName - Variable in class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
TableName - Class in org.apache.hadoop.hbase
Immutable POJO class for representing a table name.
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
name of table to create
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
name of table to delete
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
name of the table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
name of the table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
table name
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
name of the table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
name of the table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
table name
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
name of the table to check
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
name of table
tableName - Variable in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
tablename - Variable in class org.apache.hadoop.hbase.wal.WALKey
 
tableNameOrRegionName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
tableNameOrRegionName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
TableNamespaceManager - Class in org.apache.hadoop.hbase.master
This is a helper class used to manage the namespace metadata that is stored in TableName.NAMESPACE_TABLE_NAME It also mirrors updates to the ZK store by forwarding updates to ZKNamespaceManager
TableNamespaceManager(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.TableNamespaceManager
 
TableNotDisabledException - Exception in org.apache.hadoop.hbase
Thrown if a table should be offline but is not.
TableNotDisabledException() - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
 
TableNotDisabledException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
 
TableNotDisabledException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
 
TableNotDisabledException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
 
TableNotEnabledException - Exception in org.apache.hadoop.hbase
Thrown if a table should be enabled but is not.
TableNotEnabledException() - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
default constructor
TableNotEnabledException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
 
TableNotEnabledException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
 
TableNotEnabledException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
 
TableNotFoundException - Exception in org.apache.hadoop.hbase
Thrown when a table cannot be located.
TableNotFoundException() - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
 
TableNotFoundException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
 
TableNotFoundException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
 
TableNotFoundException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
 
TableOutputCommitter - Class in org.apache.hadoop.hbase.mapreduce
Small committer class that does not do anything.
TableOutputCommitter() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
TableOutputFormat - Class in org.apache.hadoop.hbase.mapred
Convert Map/Reduce output and write it to an HBase table
TableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat
 
TableOutputFormat<KEY> - Class in org.apache.hadoop.hbase.mapreduce
Convert Map/Reduce output and write it to an HBase table.
TableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
 
TableOutputFormat.TableRecordWriter - Class in org.apache.hadoop.hbase.mapred
Convert Reduce output (key, value) to (HStoreKey, KeyedDataArrayWritable) and write to an HBase table.
TableOutputFormat.TableRecordWriter(BufferedMutator) - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
Instantiate a TableRecordWriter with the HBase HClient for writing.
TableOutputFormat.TableRecordWriter(JobConf) - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
 
TableOutputFormat.TableRecordWriter - Class in org.apache.hadoop.hbase.mapreduce
Writes the reducer output to an HBase table.
TableOutputFormat.TableRecordWriter() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
 
TablePartiallyOpenException - Exception in org.apache.hadoop.hbase.snapshot
Thrown if a table should be online/offline, but is partially open.
TablePartiallyOpenException() - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
Constructs an TablePartiallyOpenException with null as its error detail message.
TablePartiallyOpenException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
 
TablePartiallyOpenException(TableName) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
 
TablePartiallyOpenException(byte[]) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
 
TablePermission - Class in org.apache.hadoop.hbase.security.access
Represents an authorization for access for the given actions, optionally restricted to the given column family or column qualifier, over the given table.
TablePermission() - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Nullary constructor for Writable, do not use
TablePermission(TableName, byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Create a new permission for the given table and (optionally) column family, allowing the given actions.
TablePermission(TableName, byte[], byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given table, restricted to the given column family and qualifier, allowing the assigned actions to be performed.
TablePermission(TableName, byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given table, family and column qualifier, allowing the actions matching the provided byte codes to be performed.
TablePermission(String, TableName, byte[], byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given namespace or table, restricted to the given column family and qualifier, allowing the assigned actions to be performed.
TablePermission(String, TableName, byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given namespace or table, family and column qualifier, allowing the actions matching the provided byte codes to be performed.
TablePermission(String, byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Creates a new permission for the given namespace, allowing the actions matching the provided byte codes to be performed.
TablePermission(String, Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
Create a new permission for the given namespace, allowing the given actions.
TableProcedureInterface - Interface in org.apache.hadoop.hbase.master.procedure
Procedures that operates on a specific Table (e.g.
TableProcedureInterface.TableOperationType - Enum in org.apache.hadoop.hbase.master.procedure
 
TableRecordReader - Class in org.apache.hadoop.hbase.mapred
Iterate over an HBase table data, return (Text, RowResult) pairs
TableRecordReader() - Constructor for class org.apache.hadoop.hbase.mapred.TableRecordReader
 
TableRecordReader - Class in org.apache.hadoop.hbase.mapreduce
Iterate over an HBase table data, return (ImmutableBytesWritable, Result) pairs.
TableRecordReader() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableRecordReader
 
TableRecordReaderImpl - Class in org.apache.hadoop.hbase.mapred
Iterate over an HBase table data, return (Text, RowResult) pairs
TableRecordReaderImpl() - Constructor for class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
TableRecordReaderImpl - Class in org.apache.hadoop.hbase.mapreduce
Iterate over an HBase table data, return (ImmutableBytesWritable, Result) pairs.
TableRecordReaderImpl() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
 
TableReduce<K extends org.apache.hadoop.io.WritableComparable,V> - Interface in org.apache.hadoop.hbase.mapred
Write a table, sorting by the input key
TableReducer<KEYIN,VALUEIN,KEYOUT> - Class in org.apache.hadoop.hbase.mapreduce
Extends the basic Reducer class to add the required key and value input/output classes.
TableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableReducer
 
TableRegionModel - Class in org.apache.hadoop.hbase.rest.model
Representation of a region of a table and its current location on the storage cluster.
TableRegionModel() - Constructor for class org.apache.hadoop.hbase.rest.model.TableRegionModel
Constructor
TableRegionModel(String, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.TableRegionModel
Constructor
TableRegionModel(String, long, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.rest.model.TableRegionModel
Constructor
TableResource - Class in org.apache.hadoop.hbase.rest
 
TableResource(String) - Constructor for class org.apache.hadoop.hbase.rest.TableResource
Constructor
TABLES_ON_MASTER - Static variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
TableScanResource - Class in org.apache.hadoop.hbase.rest
 
TableScanResource(ResultScanner, int) - Constructor for class org.apache.hadoop.hbase.rest.TableScanResource
 
TableScanResource.CellSetModelStream - Class in org.apache.hadoop.hbase.rest
 
TableScanResource.CellSetModelStream() - Constructor for class org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
 
TableScanResource.CellSetModelStream(ArrayList<RowModel>) - Constructor for class org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
 
TableSchemaMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableSchemaMessage.TableSchema - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema
TableSchemaMessage.TableSchema.Attribute - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute
TableSchemaMessage.TableSchema.Attribute.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute
TableSchemaMessage.TableSchema.AttributeOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableSchemaMessage.TableSchema.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema
TableSchemaMessage.TableSchemaOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableSchemaModel - Class in org.apache.hadoop.hbase.rest.model
A representation of HBase table descriptors.
TableSchemaModel() - Constructor for class org.apache.hadoop.hbase.rest.model.TableSchemaModel
Default constructor.
TableSchemaModel(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.rest.model.TableSchemaModel
Constructor
TableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapred
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
TableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
 
TableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapreduce
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
TableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
 
TableSnapshotInputFormat.TableSnapshotRegionSplit - Class in org.apache.hadoop.hbase.mapred
 
TableSnapshotInputFormat.TableSnapshotRegionSplit() - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
TableSnapshotInputFormat.TableSnapshotRegionSplit(TableSnapshotInputFormatImpl.InputSplit) - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
TableSnapshotInputFormat.TableSnapshotRegionSplit(HTableDescriptor, HRegionInfo, List<String>, Scan, Path) - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
TableSnapshotInputFormat.TableSnapshotRegionSplit - Class in org.apache.hadoop.hbase.mapreduce
 
TableSnapshotInputFormat.TableSnapshotRegionSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
TableSnapshotInputFormat.TableSnapshotRegionSplit(TableSnapshotInputFormatImpl.InputSplit) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
TableSnapshotInputFormat.TableSnapshotRegionSplit(HTableDescriptor, HRegionInfo, List<String>, Scan, Path) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
TableSnapshotInputFormatImpl - Class in org.apache.hadoop.hbase.mapreduce
Hadoop MR API-agnostic implementation for mapreduce over table snapshots.
TableSnapshotInputFormatImpl() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
 
TableSnapshotInputFormatImpl.InputSplit - Class in org.apache.hadoop.hbase.mapreduce
Implementation class for InputSplit logic common between mapred and mapreduce.
TableSnapshotInputFormatImpl.InputSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
 
TableSnapshotInputFormatImpl.InputSplit(HTableDescriptor, HRegionInfo, List<String>, Scan, Path) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
 
TableSnapshotInputFormatImpl.RecordReader - Class in org.apache.hadoop.hbase.mapreduce
Implementation class for RecordReader logic common between mapred and mapreduce.
TableSnapshotInputFormatImpl.RecordReader() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
 
TableSnapshotScanner - Class in org.apache.hadoop.hbase.client
A Scanner which performs a scan over snapshot files.
TableSnapshotScanner(Configuration, Path, String, Scan) - Constructor for class org.apache.hadoop.hbase.client.TableSnapshotScanner
Creates a TableSnapshotScanner.
TableSnapshotScanner(Configuration, Path, Path, String, Scan) - Constructor for class org.apache.hadoop.hbase.client.TableSnapshotScanner
Creates a TableSnapshotScanner.
tablesOnMaster - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
tablesOnMaster(Configuration) - Static method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Check if configured to put any tables on the active master
TableSplit - Class in org.apache.hadoop.hbase.mapred
A table split corresponds to a key range [low, high)
TableSplit() - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
default constructor
TableSplit(TableName, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
Constructor
TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
 
TableSplit - Class in org.apache.hadoop.hbase.mapreduce
A table split corresponds to a key range (low, high) and an optional scanner.
TableSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Default constructor.
TableSplit(byte[], Scan, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use TableSplit.TableSplit(TableName, byte[], byte[], String).
TableSplit(TableName, Scan, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Creates a new instance while assigning all variables.
TableSplit(TableName, Scan, byte[], byte[], String, long) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Creates a new instance while assigning all variables.
TableSplit(TableName, Scan, byte[], byte[], String, String, long) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Creates a new instance while assigning all variables.
TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use TableSplit.TableSplit(TableName, byte[], byte[], String).
TableSplit(TableName, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Creates a new instance without a scanner.
TableSplit(TableName, byte[], byte[], String, long) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Creates a new instance without a scanner.
TableStateManager - Interface in org.apache.hadoop.hbase
Helper class for table state management for operations running inside RegionServer or HMaster.
tableZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
tag(MetricsInfo, String) - Static method in class org.apache.hadoop.hbase.metrics.Interns
Get a metrics tag
tag(String, String, String) - Static method in class org.apache.hadoop.hbase.metrics.Interns
Get a metrics tag
Tag - Class in org.apache.hadoop.hbase
Tags are part of cells and helps to add metadata about the KVs.
Tag(byte, String) - Constructor for class org.apache.hadoop.hbase.Tag
 
Tag(byte, byte[]) - Constructor for class org.apache.hadoop.hbase.Tag
 
Tag(byte[], int) - Constructor for class org.apache.hadoop.hbase.Tag
Creates a Tag from the specified byte array and offset.
Tag(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.Tag
Creates a Tag from the specified byte array, starting at offset, and for length length.
tag(String, String, String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Add a tag to the metrics
tag(String, String, String, boolean) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Add a tag to the metrics
tag(MetricsInfo, String, boolean) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Add a tag to the metrics
tag(MetricsInfo, String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
 
TAG_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.Tag
 
TagCompressionContext - Class in org.apache.hadoop.hbase.io
Context that holds the dictionary for Tag compression and doing the compress/uncompress.
TagCompressionContext(Class<? extends Dictionary>, int) - Constructor for class org.apache.hadoop.hbase.io.TagCompressionContext
 
tagOffsetsOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
TagRewriteCell - Class in org.apache.hadoop.hbase
This can be used when a Cell has to change with addition/removal of one or more tags.
TagRewriteCell(Cell, byte[]) - Constructor for class org.apache.hadoop.hbase.TagRewriteCell
 
tags - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
tags - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
TAGS_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
Size of the tags length field in bytes
tagsBuffer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
tagsDeduplicator - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
tagsIterator(byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
Util method to iterate through the tags
tagsLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
tagsLength - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
tagsOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
tagsOffset - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
tagsOffsets - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
tagsOffsetWidth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
tagsRange - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
tagsReader - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
tagsTokenizer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
tagsWriter - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
TagType - Class in org.apache.hadoop.hbase
 
TagType() - Constructor for class org.apache.hadoop.hbase.TagType
 
tail(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
tailMap(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
tailMap(K, boolean) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
tailMap(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
tailSet(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
tailSet(Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
tailSet(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
take() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
take() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
Behaves as LinkedBlockingQueue.take(), except it will silently skip all calls which it thinks should be dropped.
take() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReaderThread
Retrieves the next batch of WAL entries from the queue, waiting up to the specified time for a batch to become available
take() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
take() - Method in class org.apache.hadoop.hbase.util.BoundedCompletionService
 
take() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
take() - Method in class org.apache.hadoop.hbase.util.StealJobQueue
 
takeSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Take a snapshot based on the enabled/disabled state of the table.
takeSnapshotAsync(HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
takeSnapshotAsync(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Take a snapshot without waiting for the server to complete that snapshot (asynchronous)
TakeSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
A handler for taking snapshots from the master.
TakeSnapshotHandler(HBaseProtos.SnapshotDescription, MasterServices, SnapshotManager) - Constructor for class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
TAppend - Class in org.apache.hadoop.hbase.thrift.generated
 
TAppend() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TAppend
 
TAppend(ByteBuffer, ByteBuffer, List<ByteBuffer>, List<ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TAppend
 
TAppend(TAppend) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TAppend
Performs a deep copy on other.
TAppend - Class in org.apache.hadoop.hbase.thrift2.generated
 
TAppend() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
TAppend(ByteBuffer, List<TColumnValue>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
TAppend(TAppend) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TAppend
Performs a deep copy on other.
tappend - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
the TAppend to append
TAppend._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TAppend._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
targetReplicaId - Variable in class org.apache.hadoop.hbase.client.Query
 
targets - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
'Target' dependent on 'mode'.
taskLoop() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
Wait for the new tasks and grab one
taskLoop() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
Wait for tasks to become available at /hbase/splitlog zknode.
TaskMonitor - Class in org.apache.hadoop.hbase.monitoring
Singleton which keeps track of tasks going on in this VM.
taskMonitor - Variable in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
TaskMonitorTmpl - Class in org.apache.hadoop.hbase.tmpl.common
 
TaskMonitorTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
TaskMonitorTmpl(String) - Constructor for class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
TaskMonitorTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
 
TaskMonitorTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.common
 
TaskMonitorTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
 
TaskMonitorTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.common
 
TaskMonitorTmplImpl - Class in org.apache.hadoop.hbase.tmpl.common
 
TaskMonitorTmplImpl(TemplateManager, TaskMonitorTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmplImpl
 
tasksInProgress - Variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
 
TAuthorization - Class in org.apache.hadoop.hbase.thrift2.generated
 
TAuthorization() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
TAuthorization(TAuthorization) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
Performs a deep copy on other.
TAuthorization._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TBoundedThreadPoolServer - Class in org.apache.hadoop.hbase.thrift
A bounded thread pool server customized for HBase.
TBoundedThreadPoolServer(TBoundedThreadPoolServer.Args, ThriftMetrics) - Constructor for class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
 
TBoundedThreadPoolServer.Args - Class in org.apache.hadoop.hbase.thrift
 
TBoundedThreadPoolServer.Args(TServerTransport, Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.Args
 
TCell - Class in org.apache.hadoop.hbase.thrift.generated
 
TCell() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TCell
 
TCell(ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TCell
 
TCell(TCell) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TCell
Performs a deep copy on other.
TCell._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCellVisibility - Class in org.apache.hadoop.hbase.thrift2.generated
 
TCellVisibility() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
TCellVisibility(TCellVisibility) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
Performs a deep copy on other.
TCellVisibility._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TColumn - Class in org.apache.hadoop.hbase.thrift.generated
 
TColumn() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TColumn
 
TColumn(ByteBuffer, TCell) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TColumn
 
TColumn(TColumn) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TColumn
Performs a deep copy on other.
TColumn - Class in org.apache.hadoop.hbase.thrift2.generated
 
TColumn() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
TColumn(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
TColumn(TColumn) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumn
Performs a deep copy on other.
TColumn._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TColumn._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TColumnIncrement - Class in org.apache.hadoop.hbase.thrift2.generated
 
TColumnIncrement() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
TColumnIncrement(ByteBuffer, ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
TColumnIncrement(TColumnIncrement) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
Performs a deep copy on other.
TColumnIncrement._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TColumnValue - Class in org.apache.hadoop.hbase.thrift2.generated
 
TColumnValue() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
TColumnValue(ByteBuffer, ByteBuffer, ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
TColumnValue(TColumnValue) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
Performs a deep copy on other.
TColumnValue._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCompareOp - Enum in org.apache.hadoop.hbase.thrift2.generated
Thrift wrapper around org.apache.hadoop.hbase.filter.CompareFilter$CompareOp.
tcpKeepAlive - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
tcpKeepAlive - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
tcpNoDelay - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
tcpNoDelay - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
TDelete - Class in org.apache.hadoop.hbase.thrift2.generated
 
TDelete() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
TDelete(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
TDelete(TDelete) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TDelete
Performs a deep copy on other.
tdelete - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
the TDelete to execute if the check succeeds
tdelete - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
the TDelete to delete
TDelete._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tdeletes - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
list of TDeletes to delete
TDeleteType - Enum in org.apache.hadoop.hbase.thrift2.generated
Specify type of delete: - DELETE_COLUMN means exactly one version will be removed, - DELETE_COLUMNS means previous versions will also be removed.
TDurability - Enum in org.apache.hadoop.hbase.thrift2.generated
Specify Durability: - SKIP_WAL means do not write the Mutation to the WAL.
TEMPORARY_FS_DIRECTORY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Config key for hbase temporary directory in hdfs
term - Variable in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
Terminal - Interface in org.apache.hadoop.hbase.hbtop.terminal
The terminal interface that is an abstraction of terminal screen.
TerminalImpl - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
The implementation of the Terminal interface.
TerminalImpl() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
TerminalImpl(String) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
TerminalPrinter - Interface in org.apache.hadoop.hbase.hbtop.terminal
The interface responsible for printing to the terminal.
TerminalPrinterImpl - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
The implementation of the TerminalPrinter interface.
TerminalSize - Class in org.apache.hadoop.hbase.hbtop.terminal
Terminal dimensions in 2-d space, measured in number of rows and columns.
TerminalSize(int, int) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
 
terminate(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
terminate(String, Exception) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
terminate(String, Exception, boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
terminate(String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
End the replication
terminate(String, Exception) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
End the replication
TerminatedWrapper<T> - Class in org.apache.hadoop.hbase.types
Wraps an existing DataType implementation as a terminated version of itself.
TerminatedWrapper(DataType<T>, byte[]) - Constructor for class org.apache.hadoop.hbase.types.TerminatedWrapper
Create a terminated version of the wrapped.
TerminatedWrapper(DataType<T>, String) - Constructor for class org.apache.hadoop.hbase.types.TerminatedWrapper
Create a terminated version of the wrapped.
terminatorPosition(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
Return the position at which term begins within src, or -1 if term is not found.
testCipherProvider(Configuration) - Static method in class org.apache.hadoop.hbase.util.EncryptionTest
Check that the configured cipher provider can be loaded and initialized, or throw an exception.
testCompression(String) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
 
testCompression(Compression.Algorithm) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
 
testEncryption(Configuration, String, byte[]) - Static method in class org.apache.hadoop.hbase.util.EncryptionTest
Check that the specified cipher can be loaded and initialized, or throw an exception.
testKeyProvider(Configuration) - Static method in class org.apache.hadoop.hbase.util.EncryptionTest
Check that the configured key provider can be loaded and initialized, or throw an exception.
testTableCoprocessorAttrs(Configuration, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Sanity check the table coprocessor attributes of the supplied schema.
TextSortReducer - Class in org.apache.hadoop.hbase.mapreduce
Emits Sorted KeyValues.
TextSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
TGet - Class in org.apache.hadoop.hbase.thrift2.generated
 
TGet() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TGet
 
TGet(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TGet
 
TGet(TGet) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TGet
Performs a deep copy on other.
tget - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
the TGet to check for
tget - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
the TGet to fetch
TGet._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tgets - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
a list of TGets to check for
tgets - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
a list of TGets to fetch, the Result list will have the Results at corresponding positions or null if there was an error
THBaseService - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService
 
THBaseService.append_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.append_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
THBaseService.append_args(ByteBuffer, TAppend) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
THBaseService.append_args(THBaseService.append_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
Performs a deep copy on other.
THBaseService.append_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.append_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.append_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
THBaseService.append_result(TResult, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
THBaseService.append_result(THBaseService.append_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
Performs a deep copy on other.
THBaseService.append_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.AsyncClient - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
THBaseService.AsyncClient.append_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.append_call(ByteBuffer, TAppend, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.append_call
 
THBaseService.AsyncClient.checkAndDelete_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.checkAndDelete_call(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndDelete_call
 
THBaseService.AsyncClient.checkAndMutate_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.checkAndMutate_call(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TCompareOp, ByteBuffer, TRowMutations, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndMutate_call
 
THBaseService.AsyncClient.checkAndPut_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.checkAndPut_call(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndPut_call
 
THBaseService.AsyncClient.closeScanner_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.closeScanner_call(int, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.closeScanner_call
 
THBaseService.AsyncClient.deleteMultiple_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.deleteMultiple_call(ByteBuffer, List<TDelete>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteMultiple_call
 
THBaseService.AsyncClient.deleteSingle_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.deleteSingle_call(ByteBuffer, TDelete, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteSingle_call
 
THBaseService.AsyncClient.exists_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.exists_call(ByteBuffer, TGet, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.exists_call
 
THBaseService.AsyncClient.existsAll_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.existsAll_call(ByteBuffer, List<TGet>, AsyncMethodCallback<THBaseService.AsyncClient.existsAll_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.existsAll_call
 
THBaseService.AsyncClient.Factory - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.Factory
 
THBaseService.AsyncClient.get_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.get_call(ByteBuffer, TGet, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.get_call
 
THBaseService.AsyncClient.getAllRegionLocations_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.getAllRegionLocations_call(ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getAllRegionLocations_call
 
THBaseService.AsyncClient.getMultiple_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.getMultiple_call(ByteBuffer, List<TGet>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getMultiple_call
 
THBaseService.AsyncClient.getRegionLocation_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.getRegionLocation_call(ByteBuffer, ByteBuffer, boolean, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getRegionLocation_call
 
THBaseService.AsyncClient.getScannerResults_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.getScannerResults_call(ByteBuffer, TScan, int, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerResults_call
 
THBaseService.AsyncClient.getScannerRows_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.getScannerRows_call(int, int, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerRows_call
 
THBaseService.AsyncClient.increment_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.increment_call(ByteBuffer, TIncrement, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.increment_call
 
THBaseService.AsyncClient.mutateRow_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.mutateRow_call(ByteBuffer, TRowMutations, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.mutateRow_call
 
THBaseService.AsyncClient.openScanner_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.openScanner_call(ByteBuffer, TScan, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.openScanner_call
 
THBaseService.AsyncClient.put_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.put_call(ByteBuffer, TPut, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.put_call
 
THBaseService.AsyncClient.putMultiple_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.putMultiple_call(ByteBuffer, List<TPut>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.putMultiple_call
 
THBaseService.AsyncIface - Interface in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor(I) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor
 
THBaseService.AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor
 
THBaseService.AsyncProcessor.append<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.append() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.append
 
THBaseService.AsyncProcessor.checkAndDelete<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.checkAndDelete() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndDelete
 
THBaseService.AsyncProcessor.checkAndMutate<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.checkAndMutate() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndMutate
 
THBaseService.AsyncProcessor.checkAndPut<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.checkAndPut() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.checkAndPut
 
THBaseService.AsyncProcessor.closeScanner<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.closeScanner() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.closeScanner
 
THBaseService.AsyncProcessor.deleteMultiple<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.deleteMultiple() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.deleteMultiple
 
THBaseService.AsyncProcessor.deleteSingle<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.deleteSingle() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.deleteSingle
 
THBaseService.AsyncProcessor.exists<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.exists() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.exists
 
THBaseService.AsyncProcessor.get<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.get() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.get
 
THBaseService.AsyncProcessor.getAllRegionLocations<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.getAllRegionLocations() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getAllRegionLocations
 
THBaseService.AsyncProcessor.getMultiple<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.getMultiple() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getMultiple
 
THBaseService.AsyncProcessor.getRegionLocation<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.getRegionLocation() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getRegionLocation
 
THBaseService.AsyncProcessor.getScannerResults<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.getScannerResults() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getScannerResults
 
THBaseService.AsyncProcessor.getScannerRows<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.getScannerRows() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.getScannerRows
 
THBaseService.AsyncProcessor.increment<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.increment() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.increment
 
THBaseService.AsyncProcessor.mutateRow<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.mutateRow() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.mutateRow
 
THBaseService.AsyncProcessor.openScanner<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.openScanner() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.openScanner
 
THBaseService.AsyncProcessor.put<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.put() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.put
 
THBaseService.AsyncProcessor.putMultiple<I extends THBaseService.AsyncIface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncProcessor.putMultiple() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncProcessor.putMultiple
 
THBaseService.checkAndDelete_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.checkAndDelete_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
THBaseService.checkAndDelete_args(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
THBaseService.checkAndDelete_args(THBaseService.checkAndDelete_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
Performs a deep copy on other.
THBaseService.checkAndDelete_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.checkAndDelete_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.checkAndDelete_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
THBaseService.checkAndDelete_result(boolean, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
THBaseService.checkAndDelete_result(THBaseService.checkAndDelete_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
Performs a deep copy on other.
THBaseService.checkAndDelete_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.checkAndMutate_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.checkAndMutate_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
THBaseService.checkAndMutate_args(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TCompareOp, ByteBuffer, TRowMutations) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
THBaseService.checkAndMutate_args(THBaseService.checkAndMutate_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
Performs a deep copy on other.
THBaseService.checkAndMutate_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.checkAndMutate_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.checkAndMutate_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
THBaseService.checkAndMutate_result(boolean, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
THBaseService.checkAndMutate_result(THBaseService.checkAndMutate_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
Performs a deep copy on other.
THBaseService.checkAndMutate_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.checkAndPut_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.checkAndPut_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
THBaseService.checkAndPut_args(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
THBaseService.checkAndPut_args(THBaseService.checkAndPut_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
Performs a deep copy on other.
THBaseService.checkAndPut_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.checkAndPut_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.checkAndPut_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
THBaseService.checkAndPut_result(boolean, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
THBaseService.checkAndPut_result(THBaseService.checkAndPut_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
Performs a deep copy on other.
THBaseService.checkAndPut_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.Client - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Client(TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
THBaseService.Client(TProtocol, TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
THBaseService.Client.Factory - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Client.Factory() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client.Factory
 
THBaseService.closeScanner_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.closeScanner_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
THBaseService.closeScanner_args(int) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
THBaseService.closeScanner_args(THBaseService.closeScanner_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
Performs a deep copy on other.
THBaseService.closeScanner_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.closeScanner_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.closeScanner_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
THBaseService.closeScanner_result(TIOError, TIllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
THBaseService.closeScanner_result(THBaseService.closeScanner_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
Performs a deep copy on other.
THBaseService.closeScanner_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.deleteMultiple_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.deleteMultiple_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
THBaseService.deleteMultiple_args(ByteBuffer, List<TDelete>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
THBaseService.deleteMultiple_args(THBaseService.deleteMultiple_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
Performs a deep copy on other.
THBaseService.deleteMultiple_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.deleteMultiple_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.deleteMultiple_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
THBaseService.deleteMultiple_result(List<TDelete>, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
THBaseService.deleteMultiple_result(THBaseService.deleteMultiple_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
Performs a deep copy on other.
THBaseService.deleteMultiple_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.deleteSingle_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.deleteSingle_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
THBaseService.deleteSingle_args(ByteBuffer, TDelete) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
THBaseService.deleteSingle_args(THBaseService.deleteSingle_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
Performs a deep copy on other.
THBaseService.deleteSingle_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.deleteSingle_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.deleteSingle_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
THBaseService.deleteSingle_result(TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
THBaseService.deleteSingle_result(THBaseService.deleteSingle_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
Performs a deep copy on other.
THBaseService.deleteSingle_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.exists_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.exists_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
THBaseService.exists_args(ByteBuffer, TGet) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
THBaseService.exists_args(THBaseService.exists_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
Performs a deep copy on other.
THBaseService.exists_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.exists_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.exists_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
THBaseService.exists_result(boolean, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
THBaseService.exists_result(THBaseService.exists_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
Performs a deep copy on other.
THBaseService.exists_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.existsAll_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.existsAll_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
THBaseService.existsAll_args(ByteBuffer, List<TGet>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
THBaseService.existsAll_args(THBaseService.existsAll_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
Performs a deep copy on other.
THBaseService.existsAll_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.existsAll_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.existsAll_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
THBaseService.existsAll_result(List<Boolean>, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
THBaseService.existsAll_result(THBaseService.existsAll_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
Performs a deep copy on other.
THBaseService.existsAll_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.get_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.get_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
THBaseService.get_args(ByteBuffer, TGet) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
THBaseService.get_args(THBaseService.get_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
Performs a deep copy on other.
THBaseService.get_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.get_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.get_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
THBaseService.get_result(TResult, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
THBaseService.get_result(THBaseService.get_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
Performs a deep copy on other.
THBaseService.get_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.getAllRegionLocations_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.getAllRegionLocations_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
THBaseService.getAllRegionLocations_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
THBaseService.getAllRegionLocations_args(THBaseService.getAllRegionLocations_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
Performs a deep copy on other.
THBaseService.getAllRegionLocations_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.getAllRegionLocations_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.getAllRegionLocations_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
THBaseService.getAllRegionLocations_result(List<THRegionLocation>, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
THBaseService.getAllRegionLocations_result(THBaseService.getAllRegionLocations_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
Performs a deep copy on other.
THBaseService.getAllRegionLocations_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.getMultiple_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.getMultiple_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
THBaseService.getMultiple_args(ByteBuffer, List<TGet>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
THBaseService.getMultiple_args(THBaseService.getMultiple_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
Performs a deep copy on other.
THBaseService.getMultiple_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.getMultiple_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.getMultiple_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
THBaseService.getMultiple_result(List<TResult>, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
THBaseService.getMultiple_result(THBaseService.getMultiple_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
Performs a deep copy on other.
THBaseService.getMultiple_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.getRegionLocation_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.getRegionLocation_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
THBaseService.getRegionLocation_args(ByteBuffer, ByteBuffer, boolean) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
THBaseService.getRegionLocation_args(THBaseService.getRegionLocation_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
Performs a deep copy on other.
THBaseService.getRegionLocation_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.getRegionLocation_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.getRegionLocation_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
THBaseService.getRegionLocation_result(THRegionLocation, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
THBaseService.getRegionLocation_result(THBaseService.getRegionLocation_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
Performs a deep copy on other.
THBaseService.getRegionLocation_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.getScannerResults_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.getScannerResults_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
THBaseService.getScannerResults_args(ByteBuffer, TScan, int) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
THBaseService.getScannerResults_args(THBaseService.getScannerResults_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
Performs a deep copy on other.
THBaseService.getScannerResults_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.getScannerResults_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.getScannerResults_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
THBaseService.getScannerResults_result(List<TResult>, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
THBaseService.getScannerResults_result(THBaseService.getScannerResults_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
Performs a deep copy on other.
THBaseService.getScannerResults_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.getScannerRows_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.getScannerRows_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
THBaseService.getScannerRows_args(int, int) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
THBaseService.getScannerRows_args(THBaseService.getScannerRows_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
Performs a deep copy on other.
THBaseService.getScannerRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.getScannerRows_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.getScannerRows_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
THBaseService.getScannerRows_result(List<TResult>, TIOError, TIllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
THBaseService.getScannerRows_result(THBaseService.getScannerRows_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
Performs a deep copy on other.
THBaseService.getScannerRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.Iface - Interface in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.increment_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.increment_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
THBaseService.increment_args(ByteBuffer, TIncrement) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
THBaseService.increment_args(THBaseService.increment_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
Performs a deep copy on other.
THBaseService.increment_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.increment_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.increment_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
THBaseService.increment_result(TResult, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
THBaseService.increment_result(THBaseService.increment_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
Performs a deep copy on other.
THBaseService.increment_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.mutateRow_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.mutateRow_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
THBaseService.mutateRow_args(ByteBuffer, TRowMutations) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
THBaseService.mutateRow_args(THBaseService.mutateRow_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
Performs a deep copy on other.
THBaseService.mutateRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.mutateRow_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.mutateRow_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
THBaseService.mutateRow_result(TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
THBaseService.mutateRow_result(THBaseService.mutateRow_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
Performs a deep copy on other.
THBaseService.mutateRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.openScanner_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.openScanner_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
THBaseService.openScanner_args(ByteBuffer, TScan) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
THBaseService.openScanner_args(THBaseService.openScanner_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
Performs a deep copy on other.
THBaseService.openScanner_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.openScanner_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.openScanner_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
THBaseService.openScanner_result(int, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
THBaseService.openScanner_result(THBaseService.openScanner_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
Performs a deep copy on other.
THBaseService.openScanner_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.Processor<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor(I) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor
 
THBaseService.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor
 
THBaseService.Processor.append<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.append() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.append
 
THBaseService.Processor.checkAndDelete<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.checkAndDelete() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndDelete
 
THBaseService.Processor.checkAndMutate<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.checkAndMutate() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndMutate
 
THBaseService.Processor.checkAndPut<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.checkAndPut() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndPut
 
THBaseService.Processor.closeScanner<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.closeScanner() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.closeScanner
 
THBaseService.Processor.deleteMultiple<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.deleteMultiple() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteMultiple
 
THBaseService.Processor.deleteSingle<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.deleteSingle() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteSingle
 
THBaseService.Processor.exists<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.exists() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.exists
 
THBaseService.Processor.existsAll<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.existsAll() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.existsAll
 
THBaseService.Processor.get<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.get() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.get
 
THBaseService.Processor.getAllRegionLocations<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.getAllRegionLocations() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getAllRegionLocations
 
THBaseService.Processor.getMultiple<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.getMultiple() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getMultiple
 
THBaseService.Processor.getRegionLocation<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.getRegionLocation() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getRegionLocation
 
THBaseService.Processor.getScannerResults<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.getScannerResults() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerResults
 
THBaseService.Processor.getScannerRows<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.getScannerRows() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerRows
 
THBaseService.Processor.increment<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.increment() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.increment
 
THBaseService.Processor.mutateRow<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.mutateRow() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.mutateRow
 
THBaseService.Processor.openScanner<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.openScanner() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.openScanner
 
THBaseService.Processor.put<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.put() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.put
 
THBaseService.Processor.putMultiple<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.Processor.putMultiple() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.putMultiple
 
THBaseService.put_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.put_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
THBaseService.put_args(ByteBuffer, TPut) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
THBaseService.put_args(THBaseService.put_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
Performs a deep copy on other.
THBaseService.put_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.put_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.put_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
THBaseService.put_result(TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
THBaseService.put_result(THBaseService.put_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
Performs a deep copy on other.
THBaseService.put_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.putMultiple_args - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.putMultiple_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
THBaseService.putMultiple_args(ByteBuffer, List<TPut>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
THBaseService.putMultiple_args(THBaseService.putMultiple_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
Performs a deep copy on other.
THBaseService.putMultiple_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseService.putMultiple_result - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.putMultiple_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
THBaseService.putMultiple_result(TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
THBaseService.putMultiple_result(THBaseService.putMultiple_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
Performs a deep copy on other.
THBaseService.putMultiple_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THBaseThreadPoolExecutor - Class in org.apache.hadoop.hbase.thrift
A ThreadPoolExecutor customized for working with HBase thrift to update metrics before and after the execution of a task.
THBaseThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThriftMetrics) - Constructor for class org.apache.hadoop.hbase.thrift.THBaseThreadPoolExecutor
 
THBaseThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory, ThriftMetrics) - Constructor for class org.apache.hadoop.hbase.thrift.THBaseThreadPoolExecutor
 
theUnsafe - Static variable in class org.apache.hadoop.hbase.util.UnsafeAccess
 
THREAD_KEEP_ALIVE_TIME_SEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
Default amount of time in seconds to keep a thread alive.
THREAD_WAKE_FREQUENCY - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for how often threads should wake up
threadDumpingIsAlive(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
 
ThreadMonitoring - Class in org.apache.hadoop.hbase.monitoring
 
ThreadMonitoring() - Constructor for class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
 
Threads - Class in org.apache.hadoop.hbase.util
Thread Utility
Threads() - Constructor for class org.apache.hadoop.hbase.util.Threads
 
threadWakeFrequency - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
THRegionInfo - Class in org.apache.hadoop.hbase.thrift2.generated
 
THRegionInfo() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
THRegionInfo(long, ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
THRegionInfo(THRegionInfo) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
Performs a deep copy on other.
THRegionInfo._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
THRegionLocation - Class in org.apache.hadoop.hbase.thrift2.generated
 
THRegionLocation() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
THRegionLocation(TServerName, THRegionInfo) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
THRegionLocation(THRegionLocation) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
Performs a deep copy on other.
THRegionLocation._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
thresholdIdleConnections - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
THRIFT_CALL_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
thrift_jsp - Class in org.apache.hadoop.hbase.generated.thrift
 
thrift_jsp() - Constructor for class org.apache.hadoop.hbase.generated.thrift.thrift_jsp
 
THRIFT_ONE_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
 
THRIFT_ONE_METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
 
THRIFT_SERVER_SOCKET_READ_TIMEOUT_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
 
THRIFT_SERVER_SOCKET_READ_TIMEOUT_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift2.ThriftServer
 
THRIFT_SERVER_SOCKET_READ_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
Amount of time in milliseconds before a server thread will timeout waiting for client to send data on a connected socket.
THRIFT_SERVER_SOCKET_READ_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.thrift2.ThriftServer
Amount of time in milliseconds before a server thread will timeout waiting for client to send data on a connected socket.
THRIFT_TWO_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
 
THRIFT_TWO_METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
 
ThriftHBaseServiceHandler - Class in org.apache.hadoop.hbase.thrift2
This class is a glue object that connects Thrift RPC calls to the HBase client API primarily defined in the HTableInterface.
ThriftHttpServlet - Class in org.apache.hadoop.hbase.thrift
Thrift Http Servlet is used for performing Kerberos authentication if security is enabled and also used for setting the user specified in "doAs" parameter.
ThriftHttpServlet(TProcessor, TProtocolFactory, UserGroupInformation, Configuration, ThriftServerRunner.HBaseHandler, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
 
ThriftMetrics - Class in org.apache.hadoop.hbase.thrift
This class is for maintaining the various statistics of thrift server and publishing them through the metrics interfaces.
ThriftMetrics(Configuration, ThriftMetrics.ThriftServerType) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
ThriftMetrics.ThriftServerType - Enum in org.apache.hadoop.hbase.thrift
 
ThriftServer - Class in org.apache.hadoop.hbase.thrift
ThriftServer- this class starts up a Thrift server which implements the Hbase API specified in the Hbase.thrift IDL file.
ThriftServer(Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServer
 
ThriftServer - Class in org.apache.hadoop.hbase.thrift2
ThriftServer - this class starts up a Thrift server which implements the HBase API specified in the HbaseClient.thrift IDL file.
ThriftServer() - Constructor for class org.apache.hadoop.hbase.thrift2.ThriftServer
 
ThriftServerRunner - Class in org.apache.hadoop.hbase.thrift
ThriftServerRunner - this class starts up a Thrift server which implements the Hbase API specified in the Hbase.thrift IDL file.
ThriftServerRunner(Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServerRunner
 
ThriftServerRunner.HBaseHandler - Class in org.apache.hadoop.hbase.thrift
The HBaseHandler is a glue object that connects Thrift RPC calls to the HBase client API primarily defined in the Admin and Table objects.
ThriftServerRunner.HBaseHandler(Configuration, UserProvider) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
ThriftServerRunner.IOErrorWithCause - Exception in org.apache.hadoop.hbase.thrift
 
ThriftServerRunner.IOErrorWithCause(Throwable) - Constructor for exception org.apache.hadoop.hbase.thrift.ThriftServerRunner.IOErrorWithCause
 
ThriftServerRunner.ResultScannerWrapper - Class in org.apache.hadoop.hbase.thrift
 
ThriftServerRunner.ResultScannerWrapper(ResultScanner, boolean) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServerRunner.ResultScannerWrapper
 
ThriftUtilities - Class in org.apache.hadoop.hbase.thrift
 
ThriftUtilities() - Constructor for class org.apache.hadoop.hbase.thrift.ThriftUtilities
 
ThriftUtilities - Class in org.apache.hadoop.hbase.thrift2
 
throttleCompaction(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
 
throttleCompaction(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
 
throttleCompaction(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
 
throttleCompaction(long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
throttleCompaction(long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
ThrottledInputStream - Class in org.apache.hadoop.hbase.io.hadoopbackport
The ThrottleInputStream provides bandwidth throttling on a specified InputStream.
ThrottledInputStream(InputStream) - Constructor for class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
 
ThrottledInputStream(InputStream, long) - Constructor for class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
 
throttleNamespace(String, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified namespace.
throttleTable(TableName, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified table.
ThrottleType - Enum in org.apache.hadoop.hbase.quotas
Describe the Throttle Type.
throttleUser(String, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified user.
throttleUser(String, TableName, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified user on the specified table.
throttleUser(String, String, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Throttle the specified user on the specified namespace.
ThrottlingException - Exception in org.apache.hadoop.hbase.quotas
Describe the throttling result.
ThrottlingException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
ThrottlingException(ThrottlingException.Type, long, String) - Constructor for exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
ThrottlingException.Type - Enum in org.apache.hadoop.hbase.quotas
 
ThroughputController - Interface in org.apache.hadoop.hbase.regionserver.throttle
A utility that constrains the total throughput of one or more simultaneous flows by sleeping when necessary.
ThroughputControlUtil - Class in org.apache.hadoop.hbase.regionserver.throttle
Helper methods for throttling
throughputDesc(long, long) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
throughputDesc(double) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
throwable(Throwable, boolean) - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
 
throwable(Throwable, boolean) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
throwable(Throwable, boolean) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
 
throwable(Throwable, boolean) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
Called when RetryingCallable.call(int) throws an exception and we are going to retry; take action to make it so we succeed on next call (clear caches, do relookup of locations, etc.).
throwInterruptedException() - Method in interface org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
 
throwNumReadRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwNumRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwNumWriteRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwReadSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwRequestSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
throwTimeoutException(long) - Method in interface org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
 
throwWriteSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
 
tickleOpening(OpenRegionCoordination.OpenRegionDetails, HRegionInfo, RegionServerServices, String) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
Heartbeats to prevent timeouts.
tickleOpening(OpenRegionCoordination.OpenRegionDetails, HRegionInfo, RegionServerServices, String) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
Update our OPENING state in zookeeper.
TIllegalArgument - Exception in org.apache.hadoop.hbase.thrift2.generated
 
TIllegalArgument() - Constructor for exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
TIllegalArgument(TIllegalArgument) - Constructor for exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
Performs a deep copy on other.
TIllegalArgument._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TIME_IN_QUEUE_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
TIME_TO_WAIT_AFTER_SHUTDOWN_MS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
Time to wait after interrupting all worker threads.
TimeBasedLimiter - Class in org.apache.hadoop.hbase.quotas
Simple time based limiter that checks the quota Throttle
timeBeforeReplicas - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
timedOut(long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
timeInQueue() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
 
timeOfOldestEdit() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
 
timeOfOldestEdit() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
timeOfOldestEdit() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
 
timeOfOldestEdit() - Method in interface org.apache.hadoop.hbase.regionserver.Store
When was the last edit done in the memstore
timeout - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
TimeoutBlockingQueue<E> - Class in org.apache.hadoop.hbase.procedure2.util
 
TimeoutBlockingQueue(TimeoutBlockingQueue.TimeoutRetriever<? super E>) - Constructor for class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
 
TimeoutBlockingQueue(int, TimeoutBlockingQueue.TimeoutRetriever<? super E>) - Constructor for class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
 
TimeoutBlockingQueue.TimeoutRetriever<T> - Interface in org.apache.hadoop.hbase.procedure2.util
 
TimeoutException - Exception in org.apache.hadoop.hbase.errorhandling
Exception for timeout of a task.
TimeoutException(String, long, long, long) - Constructor for exception org.apache.hadoop.hbase.errorhandling.TimeoutException
Exception indicating that an operation attempt has timed out
TimeoutExceptionInjector - Class in org.apache.hadoop.hbase.errorhandling
Time a given process/operation and report a failure if the elapsed time exceeds the max allowed time.
TimeoutExceptionInjector(ForeignExceptionListener, long) - Constructor for class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
Create a generic timer for a task/process.
timeoutInjector - Variable in class org.apache.hadoop.hbase.procedure.Procedure
 
TimeoutIOException - Exception in org.apache.hadoop.hbase.exceptions
Exception thrown when a blocking operation times out.
TimeoutIOException() - Constructor for exception org.apache.hadoop.hbase.exceptions.TimeoutIOException
 
TimeoutIOException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.TimeoutIOException
 
TimeoutIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.TimeoutIOException
 
TimeoutIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.TimeoutIOException
 
timer(String) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
 
timer(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
Get or construct a Timer used to measure durations and report rates.
Timer - Interface in org.apache.hadoop.hbase.metrics
A metric which encompasses a Histogram and Meter.
TimeRange - Class in org.apache.hadoop.hbase.io
Represents an interval of version timestamps.
TimeRange() - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Deprecated.
This is made @InterfaceAudience.Private in the 2.0 line and above
TimeRange(long) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Deprecated.
This is made @InterfaceAudience.Private in the 2.0 line and above
TimeRange(byte[]) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Deprecated.
This is removed in the 2.0 line and above
TimeRange(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Deprecated.
This is removed in the 2.0 line and above
TimeRange(long, long) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Deprecated.
This is made @InterfaceAudience.Private in the 2.0 line and above
timeRange - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
timeRange - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
timeRange - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
TIMERANGE - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for timerange
TIMERANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Key for Timerange information in metadata
TIMERANGE_TRACKER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for TimeRangeTracker
TimeRangeTracker - Class in org.apache.hadoop.hbase.regionserver
Stores minimum and maximum timestamp values, it is [minimumTimestamp, maximumTimestamp] in interval notation.
TimeRangeTracker() - Constructor for class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
Default constructor.
TimeRangeTracker(TimeRangeTracker) - Constructor for class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
Copy Constructor
TimeRangeTracker(long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
TimerImpl - Class in org.apache.hadoop.hbase.metrics.impl
Custom implementation of Timer.
TimerImpl() - Constructor for class org.apache.hadoop.hbase.metrics.impl.TimerImpl
 
timestamp - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
timestamp - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
timestamp
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
timestamp
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
timestamp
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
timestamp
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
timestamp
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
timestamp
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
timestamp
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
timestamp
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
timestamp
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.TCell
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
timestamp - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
TIMESTAMP_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
TIMESTAMP_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
Size of the timestamp field in bytes
TIMESTAMP_TYPE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
 
timestampDecoder - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
TimestampDecoder - Class in org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp
Given a block and its blockMeta, this will decode the timestamp for the i-th Cell in the block.
TimestampDecoder() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.TimestampDecoder
construct
timestampDeltaWidth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
timestampEncoder - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
timestampIndexesOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
timestampIndexWidth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
TIMESTAMPKEY_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
timestamps - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
TimestampsFilter - Class in org.apache.hadoop.hbase.filter
Filter that returns only cells whose timestamp (version) is in the specified list of timestamps (versions).
TimestampsFilter(List<Long>) - Constructor for class org.apache.hadoop.hbase.filter.TimestampsFilter
Constructor for filter that retains only the specified timestamps in the list.
TimestampsFilter(List<Long>, boolean) - Constructor for class org.apache.hadoop.hbase.filter.TimestampsFilter
Constructor for filter that retains only those cells whose timestamp (version) is in the specified list of timestamps.
timeToLive - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
TimeToLiveHFileCleaner - Class in org.apache.hadoop.hbase.master.cleaner
HFile cleaner that uses the timestamp of the hfile to determine if it should be deleted.
TimeToLiveHFileCleaner() - Constructor for class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
 
TimeToLiveLogCleaner - Class in org.apache.hadoop.hbase.master.cleaner
Log cleaner that uses the timestamp of the wal to determine if it should be deleted.
TimeToLiveLogCleaner() - Constructor for class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
 
timeToPurgeDeletes - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.DropDeletesCompactionScanQueryMatcher
By default, when hbase.hstore.time.to.purge.deletes is 0ms, a delete marker is always removed during a major compaction.
timeToString(TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
 
TIncrement - Class in org.apache.hadoop.hbase.thrift.generated
 
TIncrement() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
TIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
TIncrement(TIncrement) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TIncrement
Performs a deep copy on other.
tincrement - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
the TIncrement to increment
TIncrement - Class in org.apache.hadoop.hbase.thrift2.generated
 
TIncrement() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
TIncrement(ByteBuffer, List<TColumnIncrement>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
TIncrement(TIncrement) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TIncrement
Performs a deep copy on other.
TIncrement._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TIncrement._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tinfo - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
TIOError - Exception in org.apache.hadoop.hbase.thrift2.generated
 
TIOError() - Constructor for exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
TIOError(TIOError) - Constructor for exception org.apache.hadoop.hbase.thrift2.generated.TIOError
Performs a deep copy on other.
TIOError._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TMutation - Class in org.apache.hadoop.hbase.thrift2.generated
 
TMutation() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
TMutation(TMutation._Fields, Object) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
TMutation(TMutation) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
TMutation._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TNAME - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
toAppend(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to an Append
toArray(List<byte[]>) - Static method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
toArray() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
toArray(T[]) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
toArray() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
toArray(T[]) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
toArray() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
toArray(T[]) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
toArray() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
toArray(T[]) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
toArray() - Method in class org.apache.hadoop.hbase.util.SortedList
 
toArray(T[]) - Method in class org.apache.hadoop.hbase.util.SortedList
 
toAuthorizations(ClientProtos.Authorizations) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Authorizations to a client Authorizations
toAuthorizations(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Authorizations bytes to a client Authorizations
toAuthorizations(Authorizations) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer Authorizations based on a client Authorizations.
toBigDecimal(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a BigDecimal
toBigDecimal(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a BigDecimal value
toBinaryByteArrays(String[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toBinaryFromHex(byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
Takes a ASCII digit in the range A-F0-9 and returns the corresponding integer/ordinal value.
toBoolean(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
toBuilder() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
toBulkLoadDescriptor(TableName, ByteString, Map<byte[], List<Path>>, Map<String, Long>, long) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Deprecated.
use toBulkLoadDescriptor(TableName tableName, ByteString encodedRegionName, Map> storeFiles, Map storeFilesSize, long bulkloadSeqId, List clusterIds) instead.
toBulkLoadDescriptor(TableName, ByteString, Map<byte[], List<Path>>, Map<String, Long>, long, List<String>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Generates a marker for the WAL so that we propagate the notion of a bulk region load throughout the WAL, keeping track of clusters who already applied the bulk event via the passed clusterIds parameter.
toByte() - Method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
toByteArray() - Method in class org.apache.hadoop.hbase.ClusterId
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.BitComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.Filter
TODO: JAVADOC Concrete implementers can signal a failure condition in their code by throwing an IOException.
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FilterBase
Return length 0 byte array for Filters that don't require special serialization
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.LongComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
toByteArray() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
toByteArray() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
toByteArray() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
toByteArray() - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
Copies the content of this Stream into a new byte array.
toByteArray(int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
toByteArray() - Method in class org.apache.hadoop.hbase.RegionTransition
 
toByteArray(ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.replication.ReplicationSerDeHelper
 
toByteArray(ZooKeeperProtos.ReplicationState.State) - Static method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
toByteArray() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
toByteArrays(String[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toByteArrays(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toByteArrays(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toByteBufferAndRewind(Iterable<? extends KeyValue>, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
toBytes() - Method in enum org.apache.hadoop.hbase.client.IsolationLevel
 
toBytes() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
toBytes() - Method in class org.apache.hadoop.hbase.TableName
 
toBytes(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copy the bytes from position to limit into a new byte[] of the exact length and sets the position and limit back to their original values (though not thread safe).
toBytes(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Copy the given number of bytes from specified offset into a new byte[]
toBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
Returns a new byte array, copied from the given buf, from the index 0 (inclusive) to the limit (exclusive), regardless of the current position.
toBytes(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a string to a UTF-8 byte array.
toBytes(boolean) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a boolean to a byte array.
toBytes(long) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a long value to a byte array using big-endian.
toBytes(float) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toBytes(double) - Static method in class org.apache.hadoop.hbase.util.Bytes
Serialize a double as the IEEE 754 double format output.
toBytes(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert an int value to a byte array.
toBytes(short) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a short value to a byte array of Bytes.SIZEOF_SHORT bytes long.
toBytes(BigDecimal) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a BigDecimal value to a byte array
toBytesBinary(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toCell() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
toCell(Cell) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCell(CellProtos.Cell) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCellVisibility(ClientProtos.CellVisibility) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer CellVisibility to a client CellVisibility
toCellVisibility(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer CellVisibility bytes to a client CellVisibility
toCellVisibility(CellVisibility) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer CellVisibility based on a client CellVisibility.
toCompactedStoreFiles(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCompactionDescriptor(HRegionInfo, byte[], List<Path>, List<Path>, Path) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCompactionDescriptor(HRegionInfo, byte[], byte[], List<Path>, List<Path>, Path) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCompactionEventTrackerBytes(Set<String>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toComparator(ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a ByteArrayComparable to a protocol buffer Comparator
toComparator(ComparatorProtos.Comparator) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Comparator to a ByteArrayComparable
toConsistency(ClientProtos.Consistency) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toConsistency(Consistency) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toContextString() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
toCursor(Cursor) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCursor(Cell) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCursor(ClientProtos.Cursor) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toDelete(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Delete
toDelete(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Delete
toDeleteType(KeyValue.Type) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a delete KeyValue type to protocol buffer DeleteType.
toDelimitedByteArray() - Method in class org.apache.hadoop.hbase.HRegionInfo
Use this instead of HRegionInfo.toByteArray() when writing to a stream and you want to use the pb mergeDelimitedFrom (w/o the delimiter, pb reads to EOF which may not be what you want).
toDelimitedByteArray(HRegionInfo...) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Serializes given HRegionInfo's as a byte array.
toDelimitedByteArray(Message) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toDescriptiveString() - Method in class org.apache.hadoop.hbase.master.RegionState
A slower (but more easy-to-read) stringification
toDouble(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toDouble(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toDurability(ClientProtos.MutationProto.Durability) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protobuf Durability into a client Durability
toDurability(Durability) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Durability into a protbuf Durability
toException(HBaseProtos.NameBytesPair) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a stringified protocol buffer exception Parameter to a Java Exception
toFamilyString() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
toFilter(FilterProtos.Filter) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Filter to a client Filter
toFilter(Filter) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Filter to a protocol buffer Filter
toFloat(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Presumes float encoded as IEEE 754 floating-point "single format"
toFloat(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Presumes float encoded as IEEE 754 floating-point "single format"
toFlushDescriptor(WALProtos.FlushDescriptor.FlushAction, HRegionInfo, long, Map<byte[], List<Path>>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toGet(ClientProtos.Get) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Get to a client Get
toGet(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Get.
toGet(Get) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer Get based on a client Get.
toggleKillBeforeStoreUpdate - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.Testing
 
toGroupEntry(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
Returns the group entry with the group prefix for a group principal.
toHex(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a byte range into a hex string
toHex(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Convert a byte array into a hex string
toIncrement(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to an Increment
toInt(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an int value
toInt(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an int value
toInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an int value
toIntUnsafe(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an int value (Unsafe version)
toIOException(ServiceException) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Unwraps an exception from a protobuf service into the underlying (expected) IOException.
toIOException(ErrorHandlingProtos.ForeignExceptionMessage) - Static method in class org.apache.hadoop.hbase.util.ForeignExceptionUtil
 
toJSON(int) - Method in class org.apache.hadoop.hbase.client.Operation
Produces a JSON object for fingerprint and details exposure in a parseable format.
toJSON() - Method in class org.apache.hadoop.hbase.client.Operation
Produces a JSON object sufficient for description of a query in a debugging or logging context.
toJSON(String, NavigableSet<CachedBlock>) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
 
toJSON(BlockCacheUtil.CachedBlocksByFile) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
 
toJSON(BlockCache) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
 
toJSON() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
Creates a JSON object for parseable exposure of monitored tasks.
token - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
 
token - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
TOKEN_HANDLERS - Static variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
TokenDepthComparator - Class in org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize
Determines order of nodes in the output array.
TokenDepthComparator() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenDepthComparator
 
Tokenizer - Class in org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize
Data structure used in the first stage of PrefixTree encoding: accepts a sorted stream of ByteRanges splits them into a set of tokens, each held by a TokenizerNode connects the TokenizerNodes via standard java references keeps a pool of TokenizerNodes and a reusable byte[] for holding all token content
Tokenizer() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
construct
tokenizerNode - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
TokenizerNode - Class in org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize
Individual node in a Trie structure.
TokenizerNode(Tokenizer, TokenizerNode, int, int, int, int) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
construct
TokenizerRowSearchPosition - Enum in org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize
Warning: currently unused, but code is valid.
TokenizerRowSearchResult - Class in org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize
for recursively searching a PtBuilder
TokenizerRowSearchResult() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
construct
TokenizerRowSearchResult(TokenizerRowSearchPosition) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
 
TokenizerRowSearchResult(TokenizerNode) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
 
tokenLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
tokenLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
tokenLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
 
tokenOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
tokenOffsetIntoBlock - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
TokenProvider - Class in org.apache.hadoop.hbase.security.token
Provides a service for obtaining authentication tokens via the AuthenticationProtos AuthenticationService coprocessor service.
TokenProvider() - Constructor for class org.apache.hadoop.hbase.security.token.TokenProvider
 
tokens - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
tokensLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
tokenStartOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
TokenUtil - Class in org.apache.hadoop.hbase.security.token
Utility methods for obtaining authentication tokens.
TokenUtil() - Constructor for class org.apache.hadoop.hbase.security.token.TokenUtil
 
tokenWidth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
toList(long[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
 
toLong(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a long value.
toLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a long value.
toLong(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a long value.
toLongUnsafe(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an long value (Unsafe version)
toMap(int) - Method in class org.apache.hadoop.hbase.client.Delete
 
toMap(int) - Method in class org.apache.hadoop.hbase.client.Get
Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information.
toMap(int) - Method in class org.apache.hadoop.hbase.client.Mutation
Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information.
toMap(int) - Method in class org.apache.hadoop.hbase.client.Operation
Produces a Map containing a summary of the details of a query beyond the scope of the fingerprint (i.e.
toMap() - Method in class org.apache.hadoop.hbase.client.Operation
Produces a Map containing a full summary of a query.
toMap(int) - Method in class org.apache.hadoop.hbase.client.Scan
Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information.
toMap() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
 
toMap() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
Creates a string map of internal details for extensible exposure of monitored tasks.
toMutation(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a MutateRequest to Mutation
toMutation(Increment, ClientProtos.MutationProto.Builder, long) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Increment to a protobuf Mutate.
toMutation(ClientProtos.MutationProto.MutationType, Mutation) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toMutation(ClientProtos.MutationProto.MutationType, Mutation, long) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer Mutate based on a client Mutation
toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder, long) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer MutationProto based on a client Mutation.
toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer MutationProto based on a client Mutation.
toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder, long) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toNamespaceDescriptor(HBaseProtos.NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toNamespaceEntry(String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
 
toNamespaceEntry(byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
 
tooBusyException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
tooBusyException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
TOOLS - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
Denotes classes used as tools (Used from cmd line).
toPermission(AccessControlProtos.Permission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a Permission proto to a client Permission object.
toPermission(Permission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Permission to a Permission proto
toPermissionAction(AccessControlProtos.Permission.Action) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a Permission.Action proto to a client Permission.Action object.
toPermissionAction(Permission.Action) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Permission.Action to a Permission.Action proto
toPermissionActions(List<AccessControlProtos.Permission.Action>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a list of Permission.Action proto to a list of client Permission.Action objects.
toProto(String, Throwable) - Static method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
 
toProtoForeignException(String, Throwable) - Static method in class org.apache.hadoop.hbase.util.ForeignExceptionUtil
 
toProtoNamespaceDescriptor(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toProtoQuotaScope(QuotaScope) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client QuotaScope to a protocol buffer QuotaScope
toProtoQuotaScope(QuotaType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client QuotaType to a protocol buffer QuotaType
toProtoStackTraceElement(StackTraceElement[]) - Static method in class org.apache.hadoop.hbase.util.ForeignExceptionUtil
Convert a stack trace to list of StackTraceElement.
toProtoTableName(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toProtoThrottleType(ThrottleType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client ThrottleType to a protocol buffer ThrottleType
toProtoTimeUnit(TimeUnit) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client TimeUnit to a protocol buffer TimeUnit
toProtoUserInfo(UserGroupInformation) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil
 
TopScreenModel - Class in org.apache.hadoop.hbase.hbtop.screen.top
The data and business logic for the top screen.
TopScreenModel(Admin, Mode) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
TopScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.top
The presentation logic for the top screen.
TopScreenPresenter(TopScreenView, long, TopScreenModel) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
TopScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.top
The screen that provides a dynamic real-time view for the HBase metrics.
TopScreenView(Screen, Terminal, long, Admin, Mode) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
 
toPut(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Put.
toPut(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Mutate to a Put.
toQuotaScope(QuotaProtos.QuotaScope) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer QuotaScope to a client QuotaScope
toQuotaScope(QuotaProtos.QuotaType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer QuotaType to a client QuotaType
toReadType(Scan.ReadType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toReadType(ClientProtos.Scan.ReadType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toRegion - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.SwapRegionsAction
 
toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType, HRegionInfo, long, ServerName, Map<byte[], List<Path>>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType, byte[], byte[], byte[], long, ServerName, Map<byte[], List<Path>>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toReplicationLoadSink(ClusterStatusProtos.ReplicationLoadSink) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toReplicationLoadSource(ClusterStatusProtos.ReplicationLoadSource) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toReplicationLoadSourceList(List<ClusterStatusProtos.ReplicationLoadSource>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toResult(Result) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Result to a protocol buffer Result
toResult(boolean, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Result to a protocol buffer Result
toResult(ClientProtos.Result) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Result to a client Result
toResult(ClientProtos.Result, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Result to a client Result
toResultNoData(Result) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Result to a protocol buffer Result.
toScan(Scan) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client Scan to a protocol buffer Scan
toScan(ClientProtos.Scan) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Scan to a client Scan
toScanMetrics(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toScanMetrics(ScanMetrics, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toSecurityCapabilityList(List<MasterProtos.SecurityCapabilitiesResponse.Capability>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert SecurityCapabilitiesResponse.Capability to SecurityCapability
toServer - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.MoveRegionAction
 
toServer - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.SwapRegionsAction
 
toServerName(ServerName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a ServerName to a protocol buffer ServerName
toServerName(HBaseProtos.ServerName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer ServerName to a ServerName
toServerNameList(List<HBaseProtos.ServerName>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a list of protocol buffer ServerName to a list of ServerName
toShort(byte, byte) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
 
toShort(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a short value
toShort(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a short value
toShort(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to a short value
toShortString() - Method in class org.apache.hadoop.hbase.ServerName
 
toShortUnsafe(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts a byte array to an short value (Unsafe version)
toStackTrace(List<ErrorHandlingProtos.StackTraceElementMessage>) - Static method in class org.apache.hadoop.hbase.util.ForeignExceptionUtil
Unwind a serialized array of ErrorHandlingProtos.StackTraceElementMessages to a StackTraceElements.
toString(Cell, boolean) - Static method in class org.apache.hadoop.hbase.CellUtil
Returns a string representation of the cell
toString() - Method in class org.apache.hadoop.hbase.client.HTable
 
toString() - Method in class org.apache.hadoop.hbase.client.Increment
 
toString() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
 
toString(int) - Method in class org.apache.hadoop.hbase.client.Operation
Produces a string representation of this Operation.
toString() - Method in class org.apache.hadoop.hbase.client.Operation
Produces a string representation of this Operation.
toString() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
toString() - Method in class org.apache.hadoop.hbase.client.Result
 
toString() - Method in class org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
 
toString() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCaller
 
toString() - Method in class org.apache.hadoop.hbase.ClusterId
 
toString() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
toString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.ArraySearcherPool
 
toString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
standard methods
toString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
Override PrefixTreeCell.toString() with a check to see if the current cell is valid.
toString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
For debugging.
toString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
standard methods
toString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
standard methods
toString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
Object methods
toString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
toString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
printing
toString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
Generated by Eclipse
toString() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
toString() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
 
toString() - Method in class org.apache.hadoop.hbase.executor.EventHandler
 
toString() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.FilterBase
Return filter's info for debugging and logging purpose.
toString(int) - Method in class org.apache.hadoop.hbase.filter.FilterList
Deprecated. 
toString() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
toString() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
toString() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
toString(int) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
toString(int) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
toString() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
toString() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
toString() - Method in class org.apache.hadoop.hbase.hbtop.field.Size
 
toString() - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter
 
toString() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
 
toString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
toString() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
 
toString() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
toString() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
toString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
toString() - Method in class org.apache.hadoop.hbase.http.HttpServer
Return the host and port of the HttpServer, if live
toString() - Method in class org.apache.hadoop.hbase.io.crypto.Context
 
toString() - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
toString() - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
 
toString() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
 
toString() - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
 
toString() - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
 
toString() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
toString() - Method in class org.apache.hadoop.hbase.io.FileLink
 
toString() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
toString() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
 
toString(CachedBlock, long) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
 
toString() - Method in exception org.apache.hadoop.hbase.io.hfile.bucket.CacheFullException
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
toString() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
toString() - Method in class org.apache.hadoop.hbase.io.Reference
 
toString() - Method in class org.apache.hadoop.hbase.io.TimeRange
 
toString() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
toString() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
toString() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
 
toString() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
toString() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
toString() - Method in class org.apache.hadoop.hbase.KeyValue
 
toString() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
toString() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
 
toString() - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles.LoadQueueItem
 
toString() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the details about this instance as a string.
toString() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.Action
 
toString() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.AssignRegionAction
 
toString() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.MoveRegionAction
 
toString() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.SwapRegionsAction
 
toString() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
 
toString() - Method in class org.apache.hadoop.hbase.master.DeadServer
 
toString() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
 
toString() - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
 
toString() - Method in class org.apache.hadoop.hbase.master.handler.DisableTableHandler
 
toString() - Method in class org.apache.hadoop.hbase.master.handler.EnableTableHandler
 
toString() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
 
toString() - Method in class org.apache.hadoop.hbase.master.normalizer.MergeNormalizationPlan
 
toString() - Method in class org.apache.hadoop.hbase.master.normalizer.SplitNormalizationPlan
 
toString() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler.ProcedureEvent
 
toString() - Method in class org.apache.hadoop.hbase.master.RegionPlan
 
toString() - Method in class org.apache.hadoop.hbase.master.RegionState
 
toString() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
toString() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
 
toString() - Method in enum org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
 
toString() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
 
toString() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
 
toString() - Method in class org.apache.hadoop.hbase.net.Address
 
toString() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
toString() - Method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
 
toString() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
toString() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
toString() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
toString() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
 
toString() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
 
toString() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
 
toString() - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
 
toString() - Method in class org.apache.hadoop.hbase.RegionLoad
 
toString() - Method in class org.apache.hadoop.hbase.RegionLocations
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionWindow
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionRequest
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns String representation of the entry in form "key=value"
toString() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntry
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl.JournalEntryImpl
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
toString() - Method in class org.apache.hadoop.hbase.RegionTransition
 
toString() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
 
toString() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
toString() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
toString() - Method in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
 
toString() - Method in class org.apache.hadoop.hbase.rest.model.NamespacesModel
 
toString() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
toString() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
 
toString() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
 
toString() - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
 
toString() - Method in class org.apache.hadoop.hbase.rest.model.TableModel
 
toString() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
 
toString() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
toString() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
 
toString() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
toString() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
toString() - Method in class org.apache.hadoop.hbase.ScheduledChore
A summation of this chore in human readable format.
toString() - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
 
toString() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
toString() - Method in class org.apache.hadoop.hbase.security.access.Permission
 
toString() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
toString() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
 
toString() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
 
toString() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
toString() - Method in class org.apache.hadoop.hbase.security.User
 
toString() - Method in class org.apache.hadoop.hbase.security.visibility.Authorizations
 
toString() - Method in class org.apache.hadoop.hbase.security.visibility.CellVisibility
 
toString() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
 
toString() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
 
toString() - Method in enum org.apache.hadoop.hbase.security.visibility.expression.Operator
 
toString() - Method in class org.apache.hadoop.hbase.ServerLoad
 
toString() - Method in class org.apache.hadoop.hbase.ServerName
 
toString(HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
Returns a single line (no \n) representation of snapshot metadata.
toString() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
toString() - Method in class org.apache.hadoop.hbase.TableName
 
toString() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
toString() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
toString() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
toString() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.Args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
toString() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
toString() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
toString() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
toString() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
toString() - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
standard methods
toString() - Method in class org.apache.hadoop.hbase.util.Bytes
 
toString(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
toString(byte[], String, byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Joins two byte arrays together using a separator.
toString(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
This method will convert utf8 encoded bytes into a string.
toString(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
This method will convert utf8 encoded bytes into a string.
toString() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
 
toString() - Method in class org.apache.hadoop.hbase.util.Counter
 
toString() - Method in class org.apache.hadoop.hbase.util.HashedBytes
 
toString() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
toString() - Method in class org.apache.hadoop.hbase.util.IdLock.Entry
 
toString() - Method in class org.apache.hadoop.hbase.util.LongAdder
Returns the String representation of the LongAdder.sum().
toString() - Method in class org.apache.hadoop.hbase.util.NonceKey
 
toString() - Method in class org.apache.hadoop.hbase.util.Pair
 
toString() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
toString() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
 
toString() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
toString() - Method in class org.apache.hadoop.hbase.util.Triple
 
toString() - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
 
toString() - Method in interface org.apache.hadoop.hbase.wal.WAL
Human readable identifying information about the state of this WAL.
toString() - Method in class org.apache.hadoop.hbase.wal.WALKey
 
toString() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.AcquiredLock
 
toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
Deprecated.
 
toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
 
toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
toString() - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
 
toStringBinary(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write a printable representation of a byte array.
toStringBinary(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
Converts the given byte buffer to a printable representation, from the index 0 (inclusive) to the limit (exclusive), regardless of the current position.
toStringBinary(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write a printable representation of a byte array.
toStringClass() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Extend the toString() information with the procedure details e.g.
toStringCustomizedValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
toStringCustomizedValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
toStringDetailed() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
toStringDetails() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Extend the toString() information with more procedure details
toStringFirstKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
toStringLastKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
toStringMap() - Method in class org.apache.hadoop.hbase.KeyValue
Produces a string map for this key/value pair.
toStringMap() - Method in class org.apache.hadoop.hbase.wal.WALKey
Produces a string map for this key.
toStringMinusFileName(CachedBlock, long) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
 
toStringSimpleSB() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Build the StringBuilder for the simple form of procedure string.
toStringState(StringBuilder) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called from Procedure.toString() when interpolating Procedure state
toStringState(StringBuilder) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
 
toStringTableAttributes() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
toStringUtf8() - Method in class org.apache.hadoop.hbase.util.ImmutableByteArray
 
toStringWithPadding(Collection<? extends KeyValue>, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
toString
toStringWithPadding(KeyValue, int, int, int, int, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
toStruct() - Method in class org.apache.hadoop.hbase.types.StructBuilder
Retrieve the Struct represented by this.
tot_mgr_get_data_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_get_data_nonode - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_get_data_queued - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_get_data_result - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_get_data_retry - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_heartbeat - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_log_split_batch_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_log_split_batch_start - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_log_split_batch_success - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_log_split_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_log_split_start - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_log_split_success - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_missing_state_in_delete - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_new_unexpected_wals - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_node_already_exists - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_node_create_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_node_create_queued - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_node_create_result - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_node_create_retry - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_node_delete_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_node_delete_queued - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_node_delete_result - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_null_data - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_orphan_task_acquired - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_relist_logdir - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_rescan - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_rescan_deleted - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_resubmit - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_resubmit_dead_server_task - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_resubmit_failed - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_resubmit_force - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_resubmit_threshold_reached - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_resubmit_unassigned - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_task_deleted - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_unacquired_orphan_done - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_mgr_wait_for_zk_delete - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_failed_to_grab_task_exception - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_failed_to_grab_task_lost_race - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_failed_to_grab_task_no_data - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_failed_to_grab_task_owned - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_final_transition_failed - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_get_data_queued - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_get_data_result - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_get_data_retry - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_preempt_task - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_task_acquired - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_task_acquired_rescan - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_task_done - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_task_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_task_grabing - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_task_heartbeat - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_task_heartbeat_failed - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
tot_wkr_task_resigned - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
 
toTableName(TableProtos.TableName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toTablePermission(AccessControlProtos.Permission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a Permission proto to a client TablePermission object.
TOTAL_CALL_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
TOTAL_CALL_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
TOTAL_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
TOTAL_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
TOTAL_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
TOTAL_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
TOTAL_ROW_ACTION_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
TOTAL_ROW_ACTION_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
totalBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
totalByteSize - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
 
totalCells - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
totalCompactedSize - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
the total size of data processed by the currently running compaction, in bytes
totalCompactingKVs - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
the total compacting key values in currently running compaction
TOTALCOMPACTINGKVS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
totalCompressedBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
totalKeyCount - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
The total number of keys in all chunks
totalKeyLength - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Used for calculating the average key length.
totalLengthWithMvccVersion(Iterable<? extends KeyValue>, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
totalMaxKeys - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
 
TOTALSTATICBLOOMSIZEKB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
TOTALSTATICINDEXSIZEKB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
totalTagBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
totalUncompressedBytes - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Total uncompressed bytes, maybe calculate a compression ratio later.
totalUnencodedBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
totalValueBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
totalValueLength - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Used for calculating the average value length.
TotesHRegionInfo - Interface in org.apache.hadoop.hbase.master.handler
Implementors tote an HRegionInfo instance.
toThrottleType(QuotaProtos.ThrottleType) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer ThrottleType to a client ThrottleType
toTimedQuota(long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Build a protocol buffer TimedQuota
toTimeUnit(HBaseProtos.TimeUnit) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer TimeUnit to a client TimeUnit
toToken(Token<AuthenticationTokenIdentifier>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a Token instance (with embedded identifier) to the protobuf representation.
toToken(AuthenticationProtos.Token) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a protobuf Token message back into a Token instance.
toUserInfo(RPCProtos.UserInformation) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil
 
toUserPermission(UserPermission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a client user permission to a user permission proto
toUserPermission(AccessControlProtos.UserPermission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a user permission proto to a client user permission object.
toUsersAndPermissions(String, Permission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toUsersAndPermissions(ListMultimap<String, Permission>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toUsersAndPermissions(AccessControlProtos.UsersAndPermissions) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toUserTablePermissions(ListMultimap<String, TablePermission>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a ListMultimap<String, TablePermission> where key is username to a protobuf UserPermission
toUserTablePermissions(AccessControlProtos.UsersAndPermissions) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protobuf UserTablePermissions to a ListMultimap<String, TablePermission> where key is username.
tput - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
the TPut to put if the check succeeds
tput - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
the TPut to put
TPut - Class in org.apache.hadoop.hbase.thrift2.generated
 
TPut() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TPut
 
TPut(ByteBuffer, List<TColumnValue>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TPut
 
TPut(TPut) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TPut
Performs a deep copy on other.
TPut._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tputs - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
a list of TPuts to commit
tr - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
TRACE_LOG_MAX_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
trackDelete(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
trackPeerConfigChanges(ReplicationPeerConfigListener) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
Setup a callback for chanages to the replication peer config
trackPeerConfigChanges(ReplicationPeerConfigListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
 
trackTimestamps(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
Record the earlest Put timestamp.
trailer - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
trailer - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
trailerSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
trailerWarnSize - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.Filter
Deprecated.
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterBase
Deprecated.
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
Deprecated.
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
Deprecated.
transform(float[][]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
Copy a given matrix into a new matrix, transforming each row index and each column index according to the randomization scheme that was created at construction time.
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
Give the filter a chance to transform the passed KeyValue.
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterBase
By default no transformation takes place Give the filter a chance to transform the passed KeyValue.
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
For FilterList, we can consider a filter list as a node in a tree.
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
transformClusterKey(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
Separate the given key into the three configurations it should contain: hbase.zookeeper.quorum, hbase.zookeeper.client.port and zookeeper.znode.parent
transition(RegionMergeTransaction, RegionMergeTransaction.RegionMergeTransactionPhase, RegionMergeTransaction.RegionMergeTransactionPhase) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.TransactionListener
Invoked when transitioning forward from one transaction phase to another
transition(SplitTransaction, SplitTransaction.SplitTransactionPhase, SplitTransaction.SplitTransactionPhase) - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction.TransactionListener
Invoked when transitioning forward from one transaction phase to another
transitionFromOfflineToOpening(HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
Transitions region from offline to opening state.
transitionFromOfflineToOpening(HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
Transition ZK node from OFFLINE to OPENING.
transitionNode(ZooKeeperWatcher, HRegionInfo, ServerName, EventType, EventType, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Method that actually performs unassigned node transitions.
transitionNode(ZooKeeperWatcher, HRegionInfo, ServerName, EventType, EventType, int, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
 
transitionNodeClosed(ZooKeeperWatcher, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Transitions an existing unassigned node for the specified region which is currently in the CLOSING state to be in the CLOSED state.
transitionNodeOpened(ZooKeeperWatcher, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Transitions an existing unassigned node for the specified region which is currently in the OPENING state to be in the OPENED state.
transitionNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Transitions an existing unassigned node for the specified region which is currently in the OFFLINE state to be in the OPENING state.
transitionNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName, EventType) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
 
transitionOpenFromPendingOpenOrOpeningOnServer(RegionTransition, RegionState, ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
Transition a region state to OPEN from OPENING/PENDING_OPEN
transitionToFieldScreen(Screen, Terminal) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
transitionToHelpScreen(Screen, Terminal) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
transitionToModeScreen(Screen, Terminal) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
transitionToNextScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
 
transitionToNextScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenPresenter
 
transitionToNextScreen(boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
 
transitionToOpened(HRegion, OpenRegionCoordination.OpenRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
Tries to move regions to OPENED state.
transitionToOpened(HRegion, OpenRegionCoordination.OpenRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
 
translatePFFE(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
Translates exception for preemptive fast fail checks.
treatFailureAsError - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
treeDepth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
TREEMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for TreeMap
TRegionInfo - Class in org.apache.hadoop.hbase.thrift.generated
 
TRegionInfo() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
TRegionInfo(ByteBuffer, ByteBuffer, long, ByteBuffer, byte, ByteBuffer, int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
TRegionInfo(TRegionInfo) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
Performs a deep copy on other.
TRegionInfo._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TResult - Class in org.apache.hadoop.hbase.thrift2.generated
 
TResult() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TResult
 
TResult(List<TColumnValue>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TResult
 
TResult(TResult) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TResult
Performs a deep copy on other.
TResult._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
trigger() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
Trigger the timer immediately.
triggerCacheRefreshForTesting() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
Trigger a cache refresh, even if its before the next cache refresh.
triggerMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
triggerMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
triggerMajorCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Region
Trigger major compaction on all stores in the region.
triggerMajorCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
triggerNow(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
 
triggerNow() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
Triple<A,B,C> - Class in org.apache.hadoop.hbase.util
Utility class to manage a triple.
Triple(A, B, C) - Constructor for class org.apache.hadoop.hbase.util.Triple
 
trowMutations - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
mutations to apply
TRowMutations - Class in org.apache.hadoop.hbase.thrift2.generated
 
TRowMutations() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
TRowMutations(ByteBuffer, List<TMutation>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
TRowMutations(TRowMutations) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
Performs a deep copy on other.
TRowMutations._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TRowResult - Class in org.apache.hadoop.hbase.thrift.generated
 
TRowResult() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
TRowResult(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
TRowResult(TRowResult) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRowResult
Performs a deep copy on other.
TRowResult._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
truncateTable(TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Truncate a table.
truncateTable(TableName, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Truncate a table.
truncateTable(TableName, boolean, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
truncateTable(RpcController, MasterProtos.TruncateTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
truncateTable(TableName, boolean, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Truncate a table
TruncateTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
 
TruncateTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
TruncateTableProcedure(MasterProcedureEnv, TableName, boolean) - Constructor for class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
trustStore(String, String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
tryAcquire(long) - Method in interface org.apache.hadoop.hbase.InterProcessLock
Acquire the lock within a wait time.
tryAcquire(long) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Acquire the lock within a wait time.
tryAcquireNamespaceExclusiveLock(Procedure, String) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Try to acquire the exclusive lock on the specified namespace.
tryAcquireServerExclusiveLock(Procedure, ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Try to acquire the exclusive lock on the specified server.
tryAcquireServerSharedLock(Procedure, ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Try to acquire the shared lock on the specified server.
tryAcquireTableExclusiveLock(Procedure, TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Try to acquire the exclusive lock on the specified table.
tryAcquireTableSharedLock(Procedure, TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Try to acquire the shared lock on the specified table.
tryAtomicRegionLoad(HConnection, byte[], byte[], Collection<LoadIncrementalHFiles.LoadQueueItem>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
Deprecated.
As of release 0.96 (HBASE-9508). This will be removed in HBase 2.0.0. Use LoadIncrementalHFiles.tryAtomicRegionLoad(Connection, TableName, byte[], Collection).
tryAtomicRegionLoad(Connection, TableName, byte[], Collection<LoadIncrementalHFiles.LoadQueueItem>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
Attempts to do an atomic load of many hfiles into a region.
tryDropDelete(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.DropDeletesCompactionScanQueryMatcher
 
tryRegionServerReport(long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
trySkipToNextColumn(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
trySkipToNextRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
See if we should actually SEEK or rather just SKIP to the next Cell (see HBASE-13109).
tryTransitionFromOfflineToFailedOpen(RegionServerServices, HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
Tries transition region from offline to failed open.
tryTransitionFromOfflineToFailedOpen(RegionServerServices, HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
Try to transition to open.
tryTransitionFromOpeningToFailedOpen(HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
Tries transition from Opening to Failed open.
tryTransitionFromOpeningToFailedOpen(HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
This is not guaranteed to succeed, we just do our best.
ts - Variable in class org.apache.hadoop.hbase.client.Mutation
 
ts - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
Timestamp for all inserted rows
TScan - Class in org.apache.hadoop.hbase.thrift.generated
 
TScan() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TScan
 
TScan(TScan) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TScan
Performs a deep copy on other.
tscan - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
the scan object to get a Scanner for
tscan - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
the scan object to get a Scanner for
TScan - Class in org.apache.hadoop.hbase.thrift2.generated
 
TScan() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TScan
 
TScan(TScan) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TScan
Performs a deep copy on other.
TScan._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TScan._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TServerName - Class in org.apache.hadoop.hbase.thrift2.generated
 
TServerName() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
TServerName(String) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
TServerName(TServerName) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TServerName
Performs a deep copy on other.
TServerName._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TsvImporterMapper - Class in org.apache.hadoop.hbase.mapreduce
Write table content out to files in hdfs.
TsvImporterMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
TsvImporterTextMapper - Class in org.apache.hadoop.hbase.mapreduce
Write table content out to map output files.
TsvImporterTextMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
 
TTimeRange - Class in org.apache.hadoop.hbase.thrift2.generated
 
TTimeRange() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
TTimeRange(long, long) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
TTimeRange(TTimeRange) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
Performs a deep copy on other.
TTimeRange._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
ttl - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
TTL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
 
TTL_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.master.cleaner.ReplicationZKLockCleanerChore
 
TTL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
TTL_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
 
tune(HeapMemoryManager.TunerContext) - Method in interface org.apache.hadoop.hbase.regionserver.HeapMemoryTuner
Perform the heap memory tuning operation.
tune(HeapMemoryManager.TunerContext) - Method in class org.apache.hadoop.hbase.regionserver.NoOpHeapMemoryTuner
 
tuningPeriod - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
tupleSchemeReadValue(TProtocol, short) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
tupleSchemeWriteValue(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
turnOffMoveMode() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
 
turnOnMoveMode() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
 
TWENTY_FIFTH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
TwoPhaseProcedure<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
 
TwoPhaseProcedure() - Constructor for class org.apache.hadoop.hbase.procedure2.TwoPhaseProcedure
 
type - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
type - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.Action
 
type - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.MutationReplay
 
TYPE_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.Tag
 
TYPE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
Size of the key type field in bytes
typeA - Variable in class org.apache.hadoop.hbase.types.Union2
 
typeB - Variable in class org.apache.hadoop.hbase.types.Union2
 
typeBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
typeC - Variable in class org.apache.hadoop.hbase.types.Union3
 
typeD - Variable in class org.apache.hadoop.hbase.types.Union4
 
TYPES - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
static
types - Variable in class org.apache.hadoop.hbase.types.StructIterator
 

U

UFIntTool - Class in org.apache.hadoop.hbase.util.vint
UFInt is an abbreviation for Unsigned Fixed-width Integer.
UFIntTool() - Constructor for class org.apache.hadoop.hbase.util.vint.UFIntTool
 
ugi - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
ugi - Variable in class org.apache.hadoop.hbase.security.User
 
unaligned() - Static method in class org.apache.hadoop.hbase.util.UnsafeAvailChecker
 
unassign(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Unassign a region from current hosting regionserver.
unassign(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Unassign a region from current hosting regionserver.
unassign(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Unassigns the specified region.
unassign(HRegionInfo, boolean, ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Unassigns the specified region.
unassign(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
unassign(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
unassign(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
Unassign the given region from the current regionserver and assign it randomly.
UnAssignCallable - Class in org.apache.hadoop.hbase.master
A callable object that invokes the corresponding action that needs to be taken for unassignment of a region in transition.
UnAssignCallable(AssignmentManager, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.master.UnAssignCallable
 
unassignRegion(RpcController, MasterProtos.UnassignRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
unbuffer() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
This will free sockets and file descriptors held by the stream only when the stream implements org.apache.hadoop.fs.CanUnbuffer.
unbufferStream() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
To close the stream's socket.
unbufferStream() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
uncompress(ByteString, Dictionary) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.ByteStringUncompressor
 
uncompressTags(InputStream, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
Uncompress tags from the InputStream and writes to the destination array.
uncompressTags(ByteBuffer, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
Uncompress tags from the input ByteBuffer and writes to the destination array.
uncompressTags(InputStream, ByteBuffer, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
Uncompress tags from the InputStream and writes to the destination buffer.
undeleteAll() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
undeleteAll() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
undoAction() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.Action
Returns an Action which would undo this action
undoAction() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.AssignRegionAction
 
undoAction() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.MoveRegionAction
 
undoAction() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.SwapRegionsAction
 
UnexpectedStateException - Exception in org.apache.hadoop.hbase.exceptions
 
UnexpectedStateException() - Constructor for exception org.apache.hadoop.hbase.exceptions.UnexpectedStateException
 
UnexpectedStateException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnexpectedStateException
 
UnexpectedStateException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnexpectedStateException
 
UnexpectedStateException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnexpectedStateException
 
unforcedResubmits - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
UNIFIED_ENCODED_BLOCKSIZE_RATIO - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
if this feature is enabled, preCalculate encoded data size before real encoding happens
Union2<A,B> - Class in org.apache.hadoop.hbase.types
The Union family of DataTypes encode one of a fixed set of Objects.
Union2(DataType<A>, DataType<B>) - Constructor for class org.apache.hadoop.hbase.types.Union2
Create an instance of Union2 over the set of specified types.
Union3<A,B,C> - Class in org.apache.hadoop.hbase.types
The Union family of DataTypes encode one of a fixed collection of Objects.
Union3(DataType<A>, DataType<B>, DataType<C>) - Constructor for class org.apache.hadoop.hbase.types.Union3
Create an instance of Union3 over the set of specified types.
Union4<A,B,C,D> - Class in org.apache.hadoop.hbase.types
The Union family of DataTypes encode one of a fixed collection of Objects.
Union4(DataType<A>, DataType<B>, DataType<C>, DataType<D>) - Constructor for class org.apache.hadoop.hbase.types.Union4
Create an instance of Union4 over the set of specified types.
uniqueIndexByUniqueRange - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
UniqueIndexMap<T> - Class in org.apache.hadoop.hbase.io.hfile.bucket
Map from type T to int and vice-versa.
UniqueIndexMap() - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.UniqueIndexMap
 
uniqueRangeIndexByInsertionId - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
uniqueRanges - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
uniqueValues - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
fields
UNKNOWN - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
UNKNOWN_RACK - Static variable in class org.apache.hadoop.hbase.master.RackManager
 
UNKNOWN_SERVERNAME - Static variable in class org.apache.hadoop.hbase.ServerName
What to use if server name is unknown.
UnknownProtocolException - Exception in org.apache.hadoop.hbase.exceptions
An error requesting an RPC protocol that the server is not serving.
UnknownProtocolException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
UnknownProtocolException(Class<?>) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
UnknownProtocolException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
UnknownRegionException - Exception in org.apache.hadoop.hbase
Thrown when we are asked to operate on a region we know nothing about.
UnknownRegionException(String) - Constructor for exception org.apache.hadoop.hbase.UnknownRegionException
 
unknownScannerException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
unknownScannerException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
UnknownScannerException - Exception in org.apache.hadoop.hbase
Thrown if a region server is passed an unknown scanner ID.
UnknownScannerException() - Constructor for exception org.apache.hadoop.hbase.UnknownScannerException
 
UnknownScannerException(String) - Constructor for exception org.apache.hadoop.hbase.UnknownScannerException
 
UnknownScannerException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.UnknownScannerException
 
UnknownServiceException - Exception in org.apache.hadoop.hbase.ipc
 
UnknownSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
Exception thrown when we get a request for a snapshot we don't recognize.
UnknownSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.UnknownSnapshotException
 
UnknownSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.UnknownSnapshotException
 
UnmodifyableHTableDescriptor - Class in org.apache.hadoop.hbase.client
Read-only table descriptor.
UnmodifyableHTableDescriptor() - Constructor for class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
Default constructor
unquoteHtmlChars(String) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
Remove HTML quoting from a string.
unregisterAllListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Clean all existing listeners
unregisterFlushRequestListener(FlushRequestListener) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
Unregister the given FlushRequestListener
unregisterListener(EventType) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
Stop receiving updates before and after processing instances of EventType
unregisterListener(AssignmentListener) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Remove the listener from the notification list.
unregisterListener(ServerListener) - Method in class org.apache.hadoop.hbase.master.ServerManager
Remove the listener from the notification list.
unregisterListener(ProcedureExecutor.ProcedureExecutorListener) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
unregisterListener(ProcedureStore.ProcedureStoreListener) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
Remove the listener from the notification list.
unregisterListener(ProcedureStore.ProcedureStoreListener) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
 
unregisterListener(ZooKeeperListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
unregisterMBean(ObjectName) - Static method in class org.apache.hadoop.hbase.util.MBeanUtil
 
unregisterNonceIfProcedureWasNotSubmitted(NonceKey) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Remove the NonceKey if the procedure was not submitted to the executor.
unregisterSource(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.impl.GlobalMetricRegistriesAdapter
Use reflection to unregister the Hadoop metric source, since MetricsSystem#unregisterSource() is only available in Hadoop 2.6+ (HADOOP-10839)
unregisterWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
unregisterWALActionsListener(WALActionsListener) - Method in interface org.apache.hadoop.hbase.wal.WAL
Unregisters WALActionsListener
UnsafeAccess - Class in org.apache.hadoop.hbase.util
 
UnsafeAvailChecker - Class in org.apache.hadoop.hbase.util
 
unset() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
unset() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
unset() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
unset() - Method in interface org.apache.hadoop.hbase.util.ByteRange
Nullifies this ByteRange.
unset() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
unset() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
unset() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
unset() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
unset() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
UNSET_HASH_VALUE - Static variable in class org.apache.hadoop.hbase.util.AbstractByteRange
 
unsetAmmount() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
unsetAmount() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
unsetAppend() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
unsetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetAuthorizations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
unsetAuthorizations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetBatchSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
unsetBatchSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
unsetBloomFilterNbHashes() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
unsetBloomFilterType() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
unsetBloomFilterVectorSize() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
unsetCacheBlocks() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
unsetCacheBlocks() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetCaching() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
unsetCaching() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetCell() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
unsetCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
unsetCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
unsetCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
unsetColFamTimeRangeMap() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
unsetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
unsetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
unsetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
unsetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
unsetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
unsetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
unsetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
unsetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
unsetColumnFamilies() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
unsetColumnName() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
unsetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetColumnValues() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
unsetColumnValues() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
unsetCompareOp() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
unsetCompression() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
unsetDeleteType() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
unsetDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
unsetDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
unsetDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
unsetDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
unsetEndKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
unsetEndKey() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
unsetExist() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
unsetExpression() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
unsetFamily() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
unsetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
unsetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
unsetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
unsetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
unsetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
unsetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
unsetFilterString() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
unsetFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
unsetFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetHostName() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
unsetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
unsetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
unsetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
unsetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
unsetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
unsetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
unsetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
unsetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
unsetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
unsetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
unsetIa() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
unsetIa() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
unsetId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
unsetId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
unsetId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
unsetId() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
unsetIncrement() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
unsetIncrements() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
unsetInMemory() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
unsetIsDelete() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
unsetLabels() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
unsetMaxStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
unsetMaxVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
unsetMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
unsetMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
unsetMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
unsetMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
unsetMessage() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
unsetMessage() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
unsetMinStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
unsetMput() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
unsetMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
unsetMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
unsetMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
unsetMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
unsetName() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
unsetName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
unsetNbRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
unsetNumRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
unsetNumRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
unsetNumVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
unsetNumVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
unsetOffline() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
unsetPartialFlag() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
unsetPort() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
unsetPort() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
unsetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
unsetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
unsetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
unsetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
unsetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
unsetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
unsetRegionId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
unsetRegionInfo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
unsetReload() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
unsetReplicaId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
unsetReversed() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
unsetReversed() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
unsetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
unsetRowBatches() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
unsetRowBatches() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
unsetRowMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
unsetRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
unsetRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
unsetRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
unsetRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
unsetScan() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
unsetScannerId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
unsetScannerId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
unsetServerName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
unsetServerName() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
unsetSmall() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetSortColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
unsetSortedColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
unsetSplit() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
unsetStartAndPrefix() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
unsetStartCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
unsetStartKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
unsetStartKey() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
unsetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
unsetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
unsetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
unsetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
unsetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
unsetStartRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
unsetStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
unsetStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
unsetStopRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
unsetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
unsetTableName() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
unsetTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
unsetTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
unsetTags() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
unsetTappend() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
unsetTdelete() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
unsetTdelete() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
unsetTdeletes() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
unsetTget() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
unsetTget() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
unsetTgets() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
unsetTgets() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
unsetTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
unsetTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
unsetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
unsetTimeToLive() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
unsetTincrement() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
unsetTput() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
unsetTput() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
unsetTputs() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
unsetTrowMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
unsetTscan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
unsetTscan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
unsetValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
unsetValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
unsetValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
unsetValue() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
unsetValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
unsetValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
unsetValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
unsetValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
unsetValues() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
unsetVersion() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
unsetWriteToWAL() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
unsignedBinarySearch(byte[], int, int, byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
Search sorted array "a" for byte "key".
unsignedCopyAndIncrement(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Treat the byte[] as an unsigned series of bytes, most significant bits first.
UnsupportedCellCodecException - Exception in org.apache.hadoop.hbase.ipc
 
UnsupportedCellCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
 
UnsupportedCellCodecException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
 
UnsupportedCellCodecException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
 
UnsupportedCompressionCodecException - Exception in org.apache.hadoop.hbase.ipc
 
UnsupportedCompressionCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
 
UnsupportedCompressionCodecException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
 
UnsupportedCompressionCodecException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
 
unthrottleNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified namespace.
unthrottleTable(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified table.
unthrottleUser(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified user.
unthrottleUser(String, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified user on the specified table.
unthrottleUser(String, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Remove the throttling for the specified user on the specified namespace.
unwrapKey(Configuration, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
Unwrap a key by decrypting it with the secret key of the given subject.
unwrapRemoteException() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
unwrapRemoteException() - Method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
 
unwrapWALKey(Configuration, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
Unwrap a wal key by decrypting it with the secret key of the given subject.
update(ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
update(byte[], ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics
Good enough attempt.
update(byte[], byte[], R) - Method in interface org.apache.hadoop.hbase.client.coprocessor.Batch.Callback
 
update(ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RegionStats
 
update(CachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
 
update(int) - Method in interface org.apache.hadoop.hbase.metrics.Histogram
Adds a new value to the distribution.
update(long) - Method in interface org.apache.hadoop.hbase.metrics.Histogram
Adds a new value to the distribution.
update(int) - Method in class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
 
update(long) - Method in class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
 
update(long, TimeUnit) - Method in class org.apache.hadoop.hbase.metrics.impl.TimerImpl
 
update(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.metrics.Timer
Update the timer with the given duration in given time unit.
update(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
 
update(Procedure) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
The specified procedure was executed, and the new state should be written to the store.
update(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
update(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
update(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
update(QuotaLimiter, QuotaLimiter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaLimiterFactory
 
update(QuotaState) - Method in class org.apache.hadoop.hbase.quotas.QuotaState
Perform an update of the quota info based on the other quota info object.
update(RateLimiter) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
Sets the current instance of RateLimiter to a new values.
update(TimeBasedLimiter) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
 
update(QuotaState) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
Perform an update of the quota state based on the other quota state object.
update() - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
Called at the end of every StoreFile.
update() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
update() - Method in class org.apache.hadoop.hbase.replication.master.TableCFsUpdater
 
update(String) - Method in class org.apache.hadoop.hbase.replication.master.TableCFsUpdater
 
update(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
 
updateAcquiredLock(String) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Update state as to indicate that a lock is held
updateAppend() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
updateAppend(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateAppend(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the Append time histogram.
updateAppend(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateAppend() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
Update related counts of appends.
updateAppend() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
updateAppend(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
Update the Append time histogram.
updateAppend(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
 
updateAppend(String, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
updateAppend(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
updateAssignmentPlan(HRegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
Add an assignment to the plan
updateAssignmentPlan(FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
 
updateAssignmentPlanToMeta(FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
Update the assignment plan into hbase:meta
updateAssignmentTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
 
updateAssignmentTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
updateAssignmentTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
 
updateBalanceCluster(long) - Method in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
 
updateBalanceCluster(long) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancerSourceImpl
 
updateBalancerStatus(boolean) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Updates the balancer status tag reported to JMX
updateBalancerStatus(boolean) - Method in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
 
updateBalancerStatus(boolean) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancerSourceImpl
 
updateBalancerStatus(boolean) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
 
updateBalancerStatus(boolean) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
updateBulkAssignTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
 
updateBulkAssignTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
updateBulkAssignTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
 
updateBulkLoad(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateCachedLocations(TableName, byte[], byte[], Object, ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Update the location cache.
updateCachedLocations(TableName, byte[], Object, HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
updateCachedLocations(TableName, byte[], byte[], Object, ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
internal method, do not use thru HConnection
updateCachedLocations(byte[], byte[], Object, HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
updateCandidateFilesForRowKeyBefore(Iterator<StoreFile>, KeyValue, Cell) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Updates the candidate list for finding row key before.
updateCandidateFilesForRowKeyBefore(Iterator<StoreFile>, KeyValue, Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
updateCellTimestamps(Iterable<List<Cell>>, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
updateCellTimestamps(Iterable<List<Cell>>, byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Replace any cell timestamps set to HConstants#LATEST_TIMESTAMP with the provided current timestamp.
updateCheckAndDelete(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateCheckAndDelete(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update checkAndDelete histogram
updateCheckAndDelete(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateCheckAndPut(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateCheckAndPut(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update checkAndPut histogram
updateCheckAndPut(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateColumnValue(byte[], byte[], byte[], long, long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Only used by tests.
updateColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Used in tests.
updateColumnValue(byte[], byte[], byte[], long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Given the specs of a column, update it, first by inserting a new record, then removing the old one.
updateCompaction(boolean, long, int, int, long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateCompactionInputFileCount(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the compaction input number of files histogram
updateCompactionInputFileCount(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateCompactionInputSize(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the compaction total input file size histogram
updateCompactionInputSize(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateCompactionOutputFileCount(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the compaction output number of files histogram
updateCompactionOutputFileCount(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateCompactionOutputSize(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the compaction total output file size
updateCompactionOutputSize(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateCompactionTime(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the compaction time histogram, both major and minor
updateCompactionTime(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateConfiguration(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Update the configuration and trigger an online config change on the regionserver
updateConfiguration() - Method in interface org.apache.hadoop.hbase.client.Admin
Update the configuration and trigger an online config change on all the regionservers
updateConfiguration(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
updateConfiguration() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
updateConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Reload the configuration from disk.
updateConfiguration(RpcController, AdminProtos.UpdateConfigurationRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
updateConnectionAccessTime() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
Updates the access time for the current connection.
updateCostsWithAction(BaseLoadBalancer.Cluster, BaseLoadBalancer.Cluster.Action) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
updateCounters(ScanMetrics, long, Method, TaskAttemptContext, long) - Static method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
 
updateCurrBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
Updates the current block to be the given HFileBlock.
updateDelayInterval(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
updateDelayInterval(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Update delay interval of delay runner.
updateDelete() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
updateDelete(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateDelete(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the Delete time histogram
updateDelete(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateDelete() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
Update related counts of deletes.
updateDelete() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
updateDelete(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
Update the Delete time histogram
updateDelete(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
 
updateDelete(String, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
updateDelete(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
updateDeleteBatch(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateDeleteBatch(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the Delete time histogram if a batch contains a delete op
updateDeleteBatch(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateDeleteBatch(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
Update the batch Delete time histogram
updateDeleteBatch(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
 
updateDeleteBatch(String, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
updateDeleteBatch(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
updateExistingNodeData(ZooKeeperWatcher, String, byte[], int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Deprecated.
Unused
updateFavoredNodes(RpcController, AdminProtos.UpdateFavoredNodesRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
updateFavoredNodesMap(HRegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
Add an assignment to the plan
updateFiles(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
updateFlush(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateFlushMemstoreSize(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the flush memstore size histogram
updateFlushMemstoreSize(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateFlushOutputSize(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the flush output file size histogram
updateFlushOutputSize(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateFlushTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the flush time histogram
updateFlushTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateFsPreadTime(long) - Method in class org.apache.hadoop.hbase.io.MetricsIO
 
updateFsPReadTime(long) - Method in interface org.apache.hadoop.hbase.io.MetricsIOSource
Update the fs positional read time histogram
updateFsPReadTime(long) - Method in class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
 
updateFsReadTime(long) - Method in class org.apache.hadoop.hbase.io.MetricsIO
 
updateFsReadTime(long) - Method in interface org.apache.hadoop.hbase.io.MetricsIOSource
Update the fs sequential read time histogram
updateFsReadTime(long) - Method in class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
 
updateFsWriteTime(long) - Method in class org.apache.hadoop.hbase.io.MetricsIO
 
updateFsWriteTime(long) - Method in interface org.apache.hadoop.hbase.io.MetricsIOSource
Update the fs write time histogram
updateFsWriteTime(long) - Method in class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
 
updateGet(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
updateGet(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateGet(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the Get time histogram .
updateGet(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateGet(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
Update time of gets
updateGet(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
updateGet(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
Update the Get time histogram .
updateGet(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
 
updateGet(String, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
updateGet(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
updateHistogram(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Add some value to a histogram.
updateHistogram(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
updateHistogram(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
 
updateHistogram(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
updateHistogram(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
updateIncrement() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
updateIncrement(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateIncrement(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the Increment time histogram.
updateIncrement(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateIncrement() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
Update related counts of increments.
updateIncrement() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
updateIncrement(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
Update the Increment time histogram.
updateIncrement(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
 
updateIncrement(String, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
updateIncrement(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
updateKeyInZK(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
updateLatestStamp(Cell, long) - Static method in class org.apache.hadoop.hbase.CellUtil
Sets the given timestamp to the cell iff current timestamp is HConstants.LATEST_TIMESTAMP.
updateLatestStamp(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
Sets the given timestamp to the cell iff current timestamp is HConstants.LATEST_TIMESTAMP.
updateLatestStamp(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
 
updateLocation(HRegionLocation, boolean, boolean) - Method in class org.apache.hadoop.hbase.RegionLocations
Updates the location with new only if the new location has a higher seqNum than the old one or force is true.
updateMax(AtomicLong, long) - Static method in class org.apache.hadoop.hbase.util.AtomicUtils
Updates a AtomicLong which is supposed to maintain the maximum values.
updateMetaIfNecessary(MasterServices) - Static method in class org.apache.hadoop.hbase.MetaMigrationConvertingToPB
Deprecated.
Converting writable serialization to PB, if it is needed.
updateMetaParentRegions(Connection, List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
 
updateMetaWALSplitSize(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
 
updateMetaWALSplitSize(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
 
updateMetaWALSplitTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
 
updateMetaWALSplitTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
 
updateMetaWithFavoredNodesInfo(Map<HRegionInfo, List<ServerName>>, Connection) - Static method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
Update meta table with favored nodes info
updateMetaWithFavoredNodesInfo(Map<HRegionInfo, List<ServerName>>, Configuration) - Static method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
Update meta table with favored nodes info
updateMetrics(long, boolean) - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
 
updateMetricsSize(int) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
Updates the number of metrics reported to JMX
updateMetricsSize(int) - Method in interface org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSource
Updates the number of metrics reported to JMX
updateMetricsSize(int) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSourceImpl
 
updateMetricsSize(int) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
Update the number of metrics that are reported to JMX
updateMicros(long) - Method in class org.apache.hadoop.hbase.metrics.impl.TimerImpl
 
updateMicros(long) - Method in interface org.apache.hadoop.hbase.metrics.Timer
Update the timer with the given duration in microseconds
updateMillis(long) - Method in class org.apache.hadoop.hbase.metrics.impl.TimerImpl
 
updateMillis(long) - Method in interface org.apache.hadoop.hbase.metrics.Timer
Update the timer with the given duration in milliseconds
updateMin(AtomicLong, long) - Static method in class org.apache.hadoop.hbase.util.AtomicUtils
Updates a AtomicLong which is supposed to maintain the minimum values.
updateNanos(long) - Method in class org.apache.hadoop.hbase.metrics.impl.TimerImpl
 
updateNanos(long) - Method in interface org.apache.hadoop.hbase.metrics.Timer
Update the timer with the given duration in nanoseconds
updatePageSize(int) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
 
updatePauseTimeWithGc(long) - Method in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
Update the pause time histogram where GC activity was detected.
updatePauseTimeWithGc(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updatePauseTimeWithGc(long) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
updatePauseTimeWithGc(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
updatePauseTimeWithoutGc(long) - Method in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
Update the pause time histogram where GC activity was not detected.
updatePauseTimeWithoutGc(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updatePauseTimeWithoutGc(long) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
updatePauseTimeWithoutGc(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
updatePeerConfig(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
 
updatePeerConfig(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
Updates replication peer configuration and/or peer data
updatePeerConfig(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
 
updatePut() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
updatePut(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updatePut(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the Put time histogram
updatePut(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updatePut() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
Update related counts of puts.
updatePut() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
updatePut(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
Update the Put time histogram
updatePut(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
 
updatePut(String, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
updatePut(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
updatePutBatch(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updatePutBatch(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the PutBatch time histogram if a batch contains a Put op
updatePutBatch(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updatePutBatch(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
Update the batch Put time histogram
updatePutBatch(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
 
updatePutBatch(String, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
updatePutBatch(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
updateQuotaForRegionMerge(HRegionInfo) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
 
updateReaders(List<StoreFile>, List<KeyValueScanner>) - Method in interface org.apache.hadoop.hbase.regionserver.ChangedReadersObserver
Notify observers.
updateReaders(List<StoreFile>, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
updateReadFailures(String, String) - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
 
updateReadFailures(String, String) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
 
updateReadLatency(long, boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
updateReadQueryMeter(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateReadQueryMeter(TableName) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateReadRequestsCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
updateReadRequestsCount(long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Update the read request count for this region
updateRecordsSize(int) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
 
updateRegionFavoredNodesMapping(String, List<HBaseProtos.ServerName>) - Method in interface org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion
Used to update the favored nodes mapping when required.
updateRegionFavoredNodesMapping(String, List<HBaseProtos.ServerName>) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
updateRegionLocation(Connection, HRegionInfo, ServerName, long, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Updates the location of the specified region in hbase:meta to be the specified server hostname and startcode.
updateRegionsInTransitionMetrics() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Set Regions in transitions metrics.
updateRegionState(HRegionInfo, RegionState.State) - Method in class org.apache.hadoop.hbase.master.RegionStates
Update a region state.
updateRegionState(RegionTransition, RegionState.State) - Method in class org.apache.hadoop.hbase.master.RegionStates
Update a region state.
updateRegionState(HRegionInfo, RegionState.State, ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
Update a region state.
updateRegionStats(ServerName, byte[], ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
 
updateRegionStats(ServerName, byte[], ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
 
updateRegionStats(ServerName, byte[], ClientProtos.RegionLoadStats) - Method in interface org.apache.hadoop.hbase.client.StatisticTrackable
Update stats per region.
updateReplay(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateReplay(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the Replay time histogram.
updateReplay(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateReplayBatchSize(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySource
Add the batch size of each replay
updateReplayBatchSize(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySourceImpl
 
updateReplayDataSize(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySource
Add the payload data size of each replay
updateReplayDataSize(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySourceImpl
 
updateReplayTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySource
Add the time a replay command took
updateReplayTime(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySourceImpl
 
updateResultsMetrics(Result[]) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
updateRITCount(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
set new value for number of regions in transition.
updateRITCountOverThreshold(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
update RIT count that are in this state for more than the threshold as defined by the property rit.metrics.threshold.time.
updateRitDuration(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
update the duration metrics of region is transition
updateRitDuration(long) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
updateRitDuration(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
 
updateRITOldestAge(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
update the timestamp for oldest region in transition metrics.
updateRpc(MetricsConnection.CallStats) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
 
updateRpc(Descriptors.MethodDescriptor, Message, MetricsConnection.CallStats) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Report RPC context to metrics system.
UPDATES_BLOCKED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
UPDATES_BLOCKED_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
updateScanSize(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateScanSize(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the scan size.
updateScanSize(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateScanSize(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
Update the scan size.
updateScanSize(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
 
updateScanSize(String, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
updateScanSize(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
updateScanTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
updateScanTime(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateScanTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the scan time.
updateScanTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateScanTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
Update time used of resultScanner.next().
updateScanTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
updateScanTime(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
Update the scan time.
updateScanTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
 
updateScanTime(String, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
 
updateScanTime(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
updateServerStats(ServerName, byte[], Object) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
 
updateSizeMetrics(LruCachedBlock, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Helper function that updates the local size counter and also updates any per-cf or per-blocktype metrics it can discern from given LruCachedBlock
updateSnapshotCloneTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
 
updateSnapshotCloneTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
 
updateSnapshotMetrics(String, String, Histogram, Snapshot, MetricsRecordBuilder) - Static method in class org.apache.hadoop.metrics2.lib.MutableHistogram
 
updateSnapshotRangeMetrics(MetricsRecordBuilder, Snapshot) - Method in class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
 
updateSnapshotRestoreTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
 
updateSnapshotRestoreTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
 
updateSnapshotTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
 
updateSnapshotTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
 
updateSplitSize(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
 
updateSplitSize(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
 
updateSplitTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
 
updateSplitTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
 
updateSplitTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateSplitTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Update the split transaction time histogram
updateSplitTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
updateStats(T, ServerStatisticTracker, ServerName, byte[]) - Static method in class org.apache.hadoop.hbase.client.ResultStatsUtil
Update the stats for the specified region if the result is an instance of ResultStatsUtil
updateStats(StatisticTrackable, ServerName, byte[], ClientProtos.RegionLoadStats) - Static method in class org.apache.hadoop.hbase.client.ResultStatsUtil
 
updateStats(T, ServerStatisticTracker, HRegionLocation) - Static method in class org.apache.hadoop.hbase.client.ResultStatsUtil
 
updateStochasticCost(String, String, String, Double) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
Reports stochastic load balancer costs to JMX
updateStochasticCost(String, String, String, Double) - Method in interface org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSource
Reports stochastic load balancer costs to JMX
updateStochasticCost(String, String, String, Double) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSourceImpl
Reports stochastic load balancer costs to JMX
updateTableDescCache(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
updateTableReadQueryMeter(TableName, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableQueryMeter
Update table read QPS
updateTableReadQueryMeter(TableName) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableQueryMeter
Update table read QPS
updateTableReadQueryMeter(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableQueryMeterImpl
 
updateTableReadQueryMeter(TableName) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableQueryMeterImpl
 
updateTableReadQueryMeter(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
updateTableReadQueryMeter(TableName) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
updateTableWriteQueryMeter(TableName, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableQueryMeter
Update table write QPS
updateTableWriteQueryMeter(TableName) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableQueryMeter
Update table write QPS
updateTableWriteQueryMeter(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableQueryMeterImpl
 
updateTableWriteQueryMeter(TableName) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableQueryMeterImpl
 
updateTableWriteQueryMeter(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
updateTableWriteQueryMeter(TableName) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
 
updateTimestamp() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
updateTimestampToNow() - Method in class org.apache.hadoop.hbase.master.RegionState
 
updateTunables(int, int, double) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
Update tunables.
updateWriteFailures(String, String) - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
 
updateWriteFailures(String, String) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
 
updateWriteLatency(long) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
updateWriteQueryMeter(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateWriteQueryMeter(TableName) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
updateWriteRequestsCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
updateWriteRequestsCount(long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Update the write request count for this region
updateZk(boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
updateZKNamespaceManager(MasterProcedureEnv, NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
Update Zookeeper.
updateZKNamespaceManager(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
upgradeTableDirs() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
 
UpgradeTo96 - Class in org.apache.hadoop.hbase.migration
 
upsert(Iterable<Cell>, long, List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Update or insert the specified KeyValues.
upsert(Iterable<Cell>, long, List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
upsert(Iterable<Cell>, long, List<Cell>) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Update or insert the specified cells.
upsert(Iterable<Cell>, long, List<Cell>) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Adds or replaces the specified KeyValues.
url - Static variable in class org.apache.hadoop.hbase.Version
 
URL_SAFE - Static variable in class org.apache.hadoop.hbase.util.Base64
Encode using Base64-like encoding that is URL and Filename safe as described in Section 4 of RFC3548: http://www.faqs.org/rfcs/rfc3548.html.
usage() - Static method in class org.apache.hadoop.hbase.util.CompressionTest
 
usage(String) - Method in class org.apache.hadoop.hbase.util.ServerCommandLine
Print usage information for this command line.
USE_HSYNC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
USE_META_REPLICAS - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key for enabling meta replication
useDateTieredSingleOutputForMinorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
usedCount() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
useDurability() - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
 
useDurability() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
 
useEncodedScanner() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Decides whether we should use a scanner over encoded blocks.
useEncodedScanner(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
useEncodedScanner() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
useEncodedScanner() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
useHBaseChecksum() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
Are we verifying checksums in HBase?
useLegacyMethod(Class<? extends Coprocessor>, String, Class<?>...) - Static method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Used to gracefully handle fallback to deprecated methods when we evolve coprocessor APIs.
user - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
User - Class in org.apache.hadoop.hbase.security
Wrapper to abstract out usage of user and group information in HBase.
User() - Constructor for class org.apache.hadoop.hbase.security.User
 
user - Static variable in class org.apache.hadoop.hbase.Version
 
User.SecureHadoopUser - Class in org.apache.hadoop.hbase.security
Bridges User invocations to underlying calls to UserGroupInformation for secure Hadoop 0.20 and versions 0.21 and above.
User.SecureHadoopUser() - Constructor for class org.apache.hadoop.hbase.security.User.SecureHadoopUser
 
User.SecureHadoopUser(UserGroupInformation) - Constructor for class org.apache.hadoop.hbase.security.User.SecureHadoopUser
 
User.SecureHadoopUser(UserGroupInformation, LoadingCache<String, String[]>) - Constructor for class org.apache.hadoop.hbase.security.User.SecureHadoopUser
 
USER_COPROCESSORS_ENABLED_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
USER_REGION_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
useRegExp - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
useRegionFinder - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
useRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
 
userHasAccess(User, TableName, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Checks if the user has access to the full table or at least a family/qualifier for the specified action.
userHasAdministratorAccess(ServletContext, String) - Static method in class org.apache.hadoop.hbase.http.HttpServer
Get the admin ACLs from the given ServletContext and check if the given user is in the ACL.
username - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
useRowColBloom - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
UserPermission - Class in org.apache.hadoop.hbase.security.access
Represents an authorization for access over the given table, column family plus qualifier, for the given user.
UserPermission() - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Nullary constructor for Writable, do not use
UserPermission(byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user.
UserPermission(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, matching the actions with the given codes.
UserPermission(byte[], String, Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user.
UserPermission(byte[], String, byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, matching the actions with the given codes.
UserPermission(byte[], TableName, byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, table and column family.
UserPermission(byte[], TableName, byte[], byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new permission for the given user, table, column family and column qualifier.
UserPermission(byte[], TableName, byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, table, column family and qualifier, matching the actions with the given codes.
UserPermission(byte[], TablePermission) - Constructor for class org.apache.hadoop.hbase.security.access.UserPermission
Creates a new instance for the given user, table, column family and qualifier, matching the actions with the given codes.
userProvider - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
UserProvider - Class in org.apache.hadoop.hbase.security
Provide an instance of a user.
UserProvider() - Constructor for class org.apache.hadoop.hbase.security.UserProvider
 
UserQuotaState - Class in org.apache.hadoop.hbase.quotas
In-Memory state of the user quotas
UserQuotaState() - Constructor for class org.apache.hadoop.hbase.quotas.UserQuotaState
 
UserQuotaState(long) - Constructor for class org.apache.hadoop.hbase.quotas.UserQuotaState
 
UserScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
Query matcher for user scan.
UserScanQueryMatcher(Scan, ScanInfo, ColumnTracker, boolean, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
userTablesOnMaster(Configuration) - Static method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
useThisHostnameInstead - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
useZKForAssignment(Configuration) - Static method in class org.apache.hadoop.hbase.util.ConfigUtil
 
UTF8 - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
 
UTF8_CHARSET - Static variable in class org.apache.hadoop.hbase.HConstants
When we encode strings, we always specify UTF8 encoding
UTF8_ENCODING - Static variable in class org.apache.hadoop.hbase.HConstants
When we encode strings, we always specify UTF8 encoding
UVIntTool - Class in org.apache.hadoop.hbase.util.vint
Simple Variable Length Integer encoding.
UVIntTool() - Constructor for class org.apache.hadoop.hbase.util.vint.UVIntTool
 
UVLongTool - Class in org.apache.hadoop.hbase.util.vint
Simple Variable Length Integer encoding.
UVLongTool() - Constructor for class org.apache.hadoop.hbase.util.vint.UVLongTool
 

V

VALID_NAMESPACE_REGEX - Static variable in class org.apache.hadoop.hbase.TableName
 
VALID_PORT_REGEX - Static variable in class org.apache.hadoop.hbase.util.Addressing
 
VALID_TABLE_QUALIFIER_REGEX - Static variable in class org.apache.hadoop.hbase.TableName
 
VALID_USER_TABLE_REGEX - Static variable in class org.apache.hadoop.hbase.TableName
 
validate(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
Validate the file to see if it even belongs in the directory.
validate(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
validate(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
 
validate(HBaseProtos.SnapshotDescription, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Convert the passed snapshot description into a 'full' snapshot description based on default parameters, if none have been supplied.
validate() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
validate() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
validate() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
validate() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
validate() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
validate() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
validateBlockAddition(Cacheable, Cacheable, BlockCacheKey) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
Validate that the existing and newBlock are the same without including the nextBlockMetadata, if not, throw an exception.
validateClass(Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.Procedure
 
validateClusterKey(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
Verifies that the given key matches the expected format for a ZooKeeper cluster key.
validateInput(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
 
validatePut(Put) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
validatePut(Put) - Method in class org.apache.hadoop.hbase.client.HTable
 
validatePut(Put, int) - Static method in class org.apache.hadoop.hbase.client.HTable
 
validateRootPath(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Verifies root directory path is a valid URI with a scheme
validateStoreFileName(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Validate the store file name.
validateTableAndRegionCount(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
validateWALFilename(String) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
A WAL file name is of the format: <wal-name>DefaultWALProvider.WAL_FILE_NAME_DELIMITER<file-creation-timestamp>[.meta].
validOptions(String[][], DocErrorReporter) - Static method in class org.apache.hadoop.hbase.classification.tools.ExcludePrivateAnnotationsStandardDoclet
 
validOptions(String[][], DocErrorReporter) - Static method in class org.apache.hadoop.hbase.classification.tools.IncludePublicAnnotationsStandardDoclet
 
value() - Method in class org.apache.hadoop.hbase.client.Result
Returns the value of the first column in the Result.
value - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The value
value - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
amount to increment by
value - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
the expected value for the column parameter, if not provided the check is for the non-existence of the column in question
value - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
value - Variable in class org.apache.hadoop.hbase.thrift.generated.TCell
 
value - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
value - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
the expected value, if not provided the check is for the non-existence of the column in question
value - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
the expected value to be compared against, if not provided the check is for the non-existence of the column in question
value - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
the expected value, if not provided the check is for the non-existence of the column in question
value - Variable in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
 
value() - Method in class org.apache.hadoop.metrics2.lib.MutableFastCounter
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
ValueFilter - Class in org.apache.hadoop.hbase.filter
This filter is used to filter based on column value.
ValueFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ValueFilter
Constructor.
valueLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
valueLength - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
valueLengthsOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
valueLengthWidth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.Admin.MasterSwitchType
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.Consistency
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.Durability
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.Scan.ReadType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.codec.prefixtree.encode.other.ColumnNodeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchPosition
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.codec.prefixtree.scanner.CellScannerPosition
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.CompatibilitySingletonFactory.SingletonStorage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.Coprocessor.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.executor.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.executor.ExecutorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.Filter.ReturnCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.FilterList.Operator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.hbtop.field.Field
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.hbtop.field.FieldValueType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.hbtop.field.Size.Unit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.hbtop.terminal.Color
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.HConstants.Modify
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.HConstants.OperationStatusCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockPriority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.KeepDeletedCells
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier.Counters
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.AssignmentManager.ServerHostRegion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.Action.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan.Position
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.normalizer.NormalizationPlan.PlanType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.procedure.ServerProcedureInterface.ServerOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.procedure.TableProcedureInterface.TableOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.RegionState.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.monitoring.MonitoredTask.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.procedure2.StateMachineProcedure.Flow
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.DeleteState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.QuotaScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.QuotaType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.ThrottleType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.ThrottlingException.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.BloomType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.DeleteTracker.DeleteCompare
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.DeleteTracker.DeleteResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.Region.FlushResult.Result
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.Region.Operation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.RegionMergeTransactionPhase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.RegionOpeningState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ScanType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.SplitTransaction.SplitTransactionPhase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.WorkerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.access.Permission.Action
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
Returns the enum constant of this type with the specified name.
valueOf(byte) - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
Return the object represented by the code.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.SaslStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.visibility.expression.Operator
Returns the enum constant of this type with the specified name.
valueOf(String, int, long) - Static method in class org.apache.hadoop.hbase.ServerName
Retrieve an instance of ServerName.
valueOf(String) - Static method in class org.apache.hadoop.hbase.ServerName
Retrieve an instance of ServerName.
valueOf(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
Retrieve an instance of ServerName.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
Returns the enum constant of this type with the specified name.
valueOf(String, String) - Static method in class org.apache.hadoop.hbase.TableName
 
valueOf(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
 
valueOf(String) - Static method in class org.apache.hadoop.hbase.TableName
 
valueOf(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.TableName
 
valueOf(ByteBuffer, ByteBuffer) - Static method in class org.apache.hadoop.hbase.TableName
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TAppend._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.ThriftMetrics.ThriftServerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TAppend._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TAuthorization._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TCellVisibility._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TCompareOp
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDeleteType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDurability
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionLocation._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TServerName._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter.ERROR_CODE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
Returns the enum constant of this type with the specified name.
valueOf(String, PoolMap.PoolType, PoolMap.PoolType...) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.PrettyPrinter.Unit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.wal.WALKey.Version
Returns the enum constant of this type with the specified name.
valueOffset - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
 
valueOffsets - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
valueOffsetsOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
valueOffsetWidth - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
values() - Static method in enum org.apache.hadoop.hbase.client.Admin.MasterSwitchType
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.Consistency
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.Durability
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.Scan.ReadType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.codec.prefixtree.encode.other.ColumnNodeType
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
values() - Static method in enum org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchPosition
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.codec.prefixtree.scanner.CellScannerPosition
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.CompatibilitySingletonFactory.SingletonStorage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.Coprocessor.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.executor.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.executor.ExecutorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.Filter.ReturnCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.FilterList.Operator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.hbtop.field.Field
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.hbtop.field.FieldValueType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.hbtop.field.Size.Unit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.hadoop.hbase.hbtop.Record
 
values() - Static method in enum org.apache.hadoop.hbase.hbtop.terminal.Color
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.HConstants.Modify
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.HConstants.OperationStatusCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockPriority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
values() - Static method in enum org.apache.hadoop.hbase.KeepDeletedCells
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier.Counters
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.master.AssignmentManager.ServerHostRegion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.Action.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan.Position
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.master.normalizer.NormalizationPlan.PlanType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.master.procedure.ServerProcedureInterface.ServerOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.master.procedure.TableProcedureInterface.TableOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.master.RegionState.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.monitoring.MonitoredTask.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.procedure2.StateMachineProcedure.Flow
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.DeleteState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.quotas.QuotaScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.quotas.QuotaType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.quotas.ThrottleType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.quotas.ThrottlingException.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.BloomType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.DeleteTracker.DeleteCompare
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.DeleteTracker.DeleteResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.Region.FlushResult.Result
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.Region.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.RegionMergeTransactionPhase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.RegionOpeningState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.ScanType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.regionserver.SplitTransaction.SplitTransactionPhase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.WorkerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.security.access.Permission.Action
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.security.SaslStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.security.visibility.expression.Operator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.TAppend._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift.ThriftMetrics.ThriftServerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TAppend._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TAuthorization._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TCellVisibility._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TCompareOp
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDeleteType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDurability
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THRegionLocation._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TServerName._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
values() - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter.ERROR_CODE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.util.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
values() - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
 
values() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
values(K) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
values() - Static method in enum org.apache.hadoop.hbase.util.PrettyPrinter.Unit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hbase.wal.WALKey.Version
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
verifyFileIntegrity(byte[], String) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
 
verifyFileIntegrity(byte[], String) - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.PersistentIOEngine
Verify cache files's integrity
verifyMetaRegionLocation(HConnection, ZooKeeperWatcher, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Verify hbase:meta is deployed and accessible.
verifyMetaRegionLocation(HConnection, ZooKeeperWatcher, long, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Verify hbase:meta is deployed and accessible.
verifyNSUpgrade(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
 
verifyRegionPlacement(boolean) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
Verify the region placement is consistent with the assignment plan
VerifyReplication - Class in org.apache.hadoop.hbase.mapreduce.replication
This map-only job compares the data from a local table with a remote one.
VerifyReplication() - Constructor for class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
 
VerifyReplication.Verifier - Class in org.apache.hadoop.hbase.mapreduce.replication
Map-only comparator for 2 tables
VerifyReplication.Verifier() - Constructor for class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
 
VerifyReplication.Verifier.Counters - Enum in org.apache.hadoop.hbase.mapreduce.replication
 
verifySnapshot(Path, Set<String>) - Method in class org.apache.hadoop.hbase.master.snapshot.MasterSnapshotVerifier
Verify that the snapshot in the directory is a valid snapshot
verifySnapshot(Configuration, FileSystem, Path, HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Verify the validity of the snapshot
verifySnapshot(Configuration, FileSystem, SnapshotManifest) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Verify the validity of the snapshot
VERSION - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
static fields
version - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
persisted fields
VERSION - Static variable in interface org.apache.hadoop.hbase.Coprocessor
 
VERSION - Static variable in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
VERSION - Static variable in class org.apache.hadoop.hbase.security.access.Permission
 
VERSION - Static variable in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
 
version - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
VERSION - Static variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Current file format version
VERSION - Static variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
The Bloom filter version.
Version - Class in org.apache.hadoop.hbase
 
Version() - Constructor for class org.apache.hadoop.hbase.Version
 
version - Static variable in class org.apache.hadoop.hbase.Version
 
VERSION - Static variable in class org.apache.hadoop.hbase.wal.WALKey
 
VERSION_FILE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
name of version file
VERSION_FILE_WRITE_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for how often we should try to write a version file, before failing
VERSION_STRING - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
VERSION_VALUE - Static variable in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
VERSION = 3;
VersionInfo - Class in org.apache.hadoop.hbase.util
This class finds the Version information for HBase.
VersionInfo() - Constructor for class org.apache.hadoop.hbase.util.VersionInfo
 
VersionInfoUtil - Class in org.apache.hadoop.hbase.client
Class to help with parsing the version info.
VersionMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
VersionMessage.Version - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.Version
VersionMessage.Version.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.Version
VersionMessage.VersionOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
VersionModel - Class in org.apache.hadoop.hbase.rest.model
A representation of the collection of versions of the REST gateway software components.
VersionModel() - Constructor for class org.apache.hadoop.hbase.rest.model.VersionModel
Default constructor.
VersionModel(ServletContext) - Constructor for class org.apache.hadoop.hbase.rest.model.VersionModel
Constructor
VersionResource - Class in org.apache.hadoop.hbase.rest
Implements REST software version reporting
VersionResource() - Constructor for class org.apache.hadoop.hbase.rest.VersionResource
Constructor
VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
 
VERSIONSDELETED_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
vintToBytes(long) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
VISIBILITY_EXP_RESOLVER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.CellCreator
 
VISIBILITY_EXP_SERIALIZATION_FORMAT_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
 
VISIBILITY_LABEL_GENERATOR_CLASS - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
 
VISIBILITY_LABEL_SERVICE_CLASS - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
 
VISIBILITY_LABELS_ATTR_KEY - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
The string that is used as key in setting the Operation attributes for visibility labels
VISIBILITY_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
 
VisibilityClient - Class in org.apache.hadoop.hbase.security.visibility
Utility client for doing visibility labels admin operations.
VisibilityClient() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityClient
 
VisibilityConstants - Class in org.apache.hadoop.hbase.security.visibility
 
VisibilityConstants() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
 
VisibilityController - Class in org.apache.hadoop.hbase.security.visibility
Coprocessor that has both the MasterObserver and RegionObserver implemented that supports in visibility labels
VisibilityController() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
VisibilityController.VisibilityReplication - Class in org.apache.hadoop.hbase.security.visibility
A RegionServerObserver impl that provides the custom VisibilityReplicationEndpoint.
VisibilityController.VisibilityReplication() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityController.VisibilityReplication
 
VisibilityControllerNotReadyException - Exception in org.apache.hadoop.hbase.security.visibility
 
VisibilityControllerNotReadyException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.VisibilityControllerNotReadyException
 
VisibilityExpEvaluator - Interface in org.apache.hadoop.hbase.security.visibility
During the read (ie.
VisibilityExpressionResolver - Interface in org.apache.hadoop.hbase.mapreduce
Interface to convert visibility expressions into Tags for storing along with Cells in HFiles.
VisibilityLabelOrdinalProvider - Interface in org.apache.hadoop.hbase.security.visibility
 
VisibilityLabelsCache - Class in org.apache.hadoop.hbase.security.visibility
Maintains the cache for visibility labels and also uses the zookeeper to update the labels in the system.
VisibilityLabelService - Interface in org.apache.hadoop.hbase.security.visibility
The interface which deals with visibility labels and user auths admin service as well as the cell visibility expression storage part and read time evaluation.
VisibilityLabelServiceManager - Class in org.apache.hadoop.hbase.security.visibility
Manages singleton instance of VisibilityLabelService
VisibilityLabelsValidator - Class in org.apache.hadoop.hbase.security.visibility
A simple validator that validates the labels passed
VisibilityLabelsValidator() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
 
VisibilityReplicationEndpoint - Class in org.apache.hadoop.hbase.security.visibility
 
VisibilityReplicationEndpoint(ReplicationEndpoint, VisibilityLabelService) - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
VisibilityScanDeleteTracker - Class in org.apache.hadoop.hbase.security.visibility
Similar to ScanDeletTracker but tracks the visibility expression also before deciding if a Cell can be considered deleted
VisibilityScanDeleteTracker() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
 
VisibilityUtils - Class in org.apache.hadoop.hbase.security.visibility
Utility method to support visibility
VisibilityUtils() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
 
visit(Result) - Method in interface org.apache.hadoop.hbase.MetaTableAccessor.Visitor
Visit the catalog table row.
visitAllLocks(InterProcessLock.MetadataHandler) - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
 
visitAllLocks(InterProcessLock.MetadataHandler) - Method in class org.apache.hadoop.hbase.master.TableLockManager
Visits all table locks(read and write), and lock attempts with the given callback MetadataHandler.
visitLocks(InterProcessLock.MetadataHandler) - Method in interface org.apache.hadoop.hbase.InterProcessLock
Visits the locks (both held and attempted) of this type with the given InterProcessLock.MetadataHandler.
visitLocks(InterProcessLock.MetadataHandler) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Visits the locks (both held and attempted) with the given MetadataHandler.
visitLogEntryBeforeWrite(HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
 
visitLogEntryBeforeWrite(HTableDescriptor, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
 
visitLogEntryBeforeWrite(HRegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
Called before each write.
visitLogEntryBeforeWrite(HTableDescriptor, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
 
visitLogEntryBeforeWrite(HTableDescriptor, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
visitNamespaceQuotas(String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.NamespaceQuotasVisitor
 
visitReferencedFiles(Configuration, FileSystem, Path, SnapshotReferenceUtil.SnapshotVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Iterate over the snapshot store files
visitReferencedFiles(Configuration, FileSystem, Path, HBaseProtos.SnapshotDescription, SnapshotReferenceUtil.SnapshotVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Iterate over the snapshot store files, restored.edits and logs
visitRegionStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
Iterate over the region store files
visitTableQuotas(TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.TableQuotasVisitor
 
visitTableStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
Iterate over the table store files
visitUserQuotas(String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
 
visitUserQuotas(String, TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
 
visitUserQuotas(String, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
 

W

W - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'W'
WAIT_BEFORE_ROLL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
WAIT_ON_REGIONSERVERS_INTERVAL - Static variable in class org.apache.hadoop.hbase.master.ServerManager
 
WAIT_ON_REGIONSERVERS_MAXTOSTART - Static variable in class org.apache.hadoop.hbase.master.ServerManager
 
WAIT_ON_REGIONSERVERS_MINTOSTART - Static variable in class org.apache.hadoop.hbase.master.ServerManager
 
WAIT_ON_REGIONSERVERS_TIMEOUT - Static variable in class org.apache.hadoop.hbase.master.ServerManager
 
waitEvent(MasterProcedureScheduler.ProcedureEvent, Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
waitEvent(MasterProcedureScheduler.ProcedureEvent, Procedure, boolean) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
waitFor(MasterProcedureEnv, String, ProcedureSyncWait.Predicate<T>) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
waitFor(MasterProcedureEnv, long, long, String, ProcedureSyncWait.Predicate<T>) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
waitForAssignment(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Waits until the specified region has completed assignment.
waitForAssignment(Collection<HRegionInfo>, boolean, int, long) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Waits until the specified region has completed assignment, or the deadline is reached.
waitForAssignment(Collection<HRegionInfo>, boolean, long) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Waits until the specified region has completed assignment, or the deadline is reached.
waitForBaseZNode(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Waits for HBase installation's base (parent) znode to become available.
waitForCompleted() - Method in class org.apache.hadoop.hbase.procedure.Procedure
Waits until the entire procedure has globally completed, or has been aborted.
waitForCompletedWithRet() - Method in class org.apache.hadoop.hbase.procedure.Procedure
Waits until the entire procedure has globally completed, or has been aborted.
waitForFlushes() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
waitForFlushes() - Method in interface org.apache.hadoop.hbase.regionserver.Region
Wait for all current flushes of the region to complete
waitForFlushesAndCompactions() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
waitForFlushesAndCompactions() - Method in interface org.apache.hadoop.hbase.regionserver.Region
Wait for all current flushes and compactions of the region to complete
waitForLatch(CountDownLatch, ForeignExceptionSnare, long, String) - Static method in class org.apache.hadoop.hbase.procedure.Procedure
Wait for latch to count to zero, ignoring any spurious wake-ups, but waking periodically to check for errors
waitForLocallyCompleted() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
Waits until the entire procedure has globally completed, or has been aborted.
waitForMasterActive() - Method in class org.apache.hadoop.hbase.master.HMaster
If configured to put regions on active master, wait till a backup master becomes active.
waitForMasterActive() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
waitForProcedureToComplete(ProcedureExecutor<MasterProcedureEnv>, long) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
waitForRegionMergeTransaction(RegionServerServices, HRegionInfo, HRegion, HRegion, RegionMergeCoordination.RegionMergeDetails) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
Get everything ready for region merge
waitForRegionMergeTransaction(RegionServerServices, HRegionInfo, HRegion, HRegion, RegionMergeCoordination.RegionMergeDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
Wait for the merging node to be transitioned from pending_merge to merging by master.
waitForRegionServers(MonitoredTask) - Method in class org.apache.hadoop.hbase.master.ServerManager
Wait for the region servers to report in.
waitForServerOnline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
waitForServerOnline() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
Block until the region server has come online, indicating it is ready to be used.
waitForSplitTransaction(RegionServerServices, Region, HRegionInfo, HRegionInfo, SplitTransactionCoordination.SplitTransactionDetails) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
Wait while coordination process the transaction
waitForSplitTransaction(RegionServerServices, Region, HRegionInfo, HRegionInfo, SplitTransactionCoordination.SplitTransactionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
Wait for the splitting node to be transitioned from pending_split to splitting by master.
waitForState(long, HBaseAdmin.ProcedureFuture.WaitForStateCallable) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
waitForUpdate(long) - Method in class org.apache.hadoop.hbase.master.RegionStates
Wait for the state map to be updated by assignment manager.
waitForWaiters(long, int) - Method in class org.apache.hadoop.hbase.util.IdLock
 
waitForWaiters(long, int) - Method in class org.apache.hadoop.hbase.util.IdReadWriteLock
 
waiting() - Method in interface org.apache.hadoop.hbase.master.ServerListener
Started waiting on RegionServers to check-in.
waiting() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
waitingTimeForEvents - Variable in class org.apache.hadoop.hbase.executor.EventHandler
 
waitInitialized(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
waitInterval() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
 
waitInterval(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
 
waitMetaRegionLocation(ZooKeeperWatcher, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Gets the meta region location, if available, and waits for up to the specified timeout if not immediately available.
waitMetaRegionLocation(ZooKeeperWatcher, int, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Gets the meta region location, if available, and waits for up to the specified timeout if not immediately available.
waitMetaRegionLocation(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Waits indefinitely for availability of hbase:meta.
waitMetaRegions(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
waitOnMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Wait for the specified master to stop.
waitOnMaster(JVMClusterUtil.MasterThread) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Wait for the specified master to stop.
waitOnRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Wait for the specified region server to stop.
waitOnRegionServer(JVMClusterUtil.RegionServerThread) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Wait for the specified region server to stop.
waitOnRegionToClearRegionsInTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Wait on region to clear regions-in-transition.
waitOnRegionToClearRegionsInTransition(HRegionInfo, long) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Wait on region to clear regions-in-transition or time out
waitOnRegionToClearRegionsInTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
Wait on region to clear regions-in-transition.
waitOnSafeMode(Configuration, long) - Static method in class org.apache.hadoop.hbase.util.FSUtils
If DFS, check safe mode and if so, wait until we clear it.
waitOperationResult(long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Fallback implementation in case the procedure is not supported by the server.
waitRegionInTransition(MasterProcedureEnv, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
waitRegionServers(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
waitServerCrashProcessingEnabled(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
waitToBecomeLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
Blocks until this instance has claimed the leader ZNode in ZooKeeper
waitUntilAssigned(Admin, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
 
waitUntilDone(long) - Method in class org.apache.hadoop.hbase.master.BulkAssigner
Wait until bulk assign is done.
waitUntilDone(long) - Method in class org.apache.hadoop.hbase.master.BulkReOpen
Reopen the regions asynchronously, so always returns true immediately.
waitUntilDone(long) - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
 
waitUntilDrained() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.EntryBuffers
 
wake(MasterProcedureScheduler.ProcedureEvent) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
wake(MasterProcedureScheduler.ProcedureEvent) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
wakeFrequency - Variable in class org.apache.hadoop.hbase.procedure.Procedure
frequency to check for errors (ms)
wakeFrequency - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
frequency to check for errors (ms)
WAL - Interface in org.apache.hadoop.hbase.wal
A Write Ahead Log (WAL) provides service for reading, writing waledits.
WAL.Entry - Class in org.apache.hadoop.hbase.wal
Utility class that lets us keep track of the edit with it's key.
WAL.Entry() - Constructor for class org.apache.hadoop.hbase.wal.WAL.Entry
 
WAL.Entry(WALKey, WALEdit) - Constructor for class org.apache.hadoop.hbase.wal.WAL.Entry
Constructor for both params
WAL.Reader - Interface in org.apache.hadoop.hbase.wal
When outside clients need to consume persisted WALs, they rely on a provided Reader.
WAL_CELL_CODEC_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
Configuration key for the class to use when encoding cells in the WAL
WAL_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
WAL_DURABILITY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
WAL_FILE_NAME_DELIMITER - Static variable in class org.apache.hadoop.hbase.wal.DefaultWALProvider
 
WAL_OFF - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
Property value to disable write-ahead logging
WAL_ON - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
Property value to use write-ahead logging
WAL_PROPERTY - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
Set this to MultiTableOutputFormat.WAL_OFF to turn off write-ahead logging (WAL)
WAL_PROVIDER - Static variable in class org.apache.hadoop.hbase.wal.WALFactory
 
WAL_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration name of WAL storage policy Valid values are: NONE: no preference in destination of block replicas ONE_SSD: place only one block replica in SSD and the remaining in default storage and ALL_SSD: place all block replicas on SSD See http://hadoop.apache.org/docs/r2.6.0/hadoop-project-dist/hadoop-hdfs/ArchivalStorage.html
WALActionsListener - Interface in org.apache.hadoop.hbase.regionserver.wal
Get notification of WAL events.
WALActionsListener.Base - Class in org.apache.hadoop.hbase.regionserver.wal
 
WALActionsListener.Base() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
 
WALCellCodec - Class in org.apache.hadoop.hbase.regionserver.wal
Compression in this class is lifted off Compressor/KeyValueCompression.
WALCellCodec() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
All subclasses must implement a no argument constructor
WALCellCodec(Configuration, CompressionContext) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
Default constructor - all subclasses must implement a constructor with this signature if they are to be dynamically loaded from the Configuration.
WALCellCodec.ByteStringCompressor - Interface in org.apache.hadoop.hbase.regionserver.wal
 
WALCellCodec.ByteStringUncompressor - Interface in org.apache.hadoop.hbase.regionserver.wal
 
WALCellCodec.EnsureKvEncoder - Class in org.apache.hadoop.hbase.regionserver.wal
 
WALCellCodec.EnsureKvEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.EnsureKvEncoder
 
WALCellFilter - Interface in org.apache.hadoop.hbase.replication
A filter for WAL entry cells before being sent over to replication.
WALCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
 
WALCoprocessorHost - Class in org.apache.hadoop.hbase.regionserver.wal
Implements the coprocessor environment and runtime support for coprocessors loaded within a WAL.
WALCoprocessorHost(WAL, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
Constructor
walDir - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
 
WALEdit - Class in org.apache.hadoop.hbase.regionserver.wal
WALEdit: Used in HBase's transaction log (WAL) to represent the collection of edits (KeyValue objects) corresponding to a single transaction.
WALEdit() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
WALEdit(boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
WALEdit(int) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
WALEdit(int, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
WALEditsReplaySink - Class in org.apache.hadoop.hbase.regionserver.wal
This class is responsible for replaying the edits coming from a failed region server.
WALEditsReplaySink(Configuration, TableName, HConnection) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALEditsReplaySink
Create a sink for WAL log entries replay
WALEntryFilter - Interface in org.apache.hadoop.hbase.replication
A Filter for WAL entries before being sent over to replication.
WALEntryStream - Class in org.apache.hadoop.hbase.replication.regionserver
Streaming access to WAL entries.
WALEntryStream(PriorityBlockingQueue<Path>, FileSystem, Configuration, MetricsSource) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
Create an entry stream over the given queue
WALEntryStream(PriorityBlockingQueue<Path>, FileSystem, Configuration, long, MetricsSource) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
Create an entry stream over the given queue at the given start position
WALEntryStream.WALEntryStreamRuntimeException - Exception in org.apache.hadoop.hbase.replication.regionserver
 
WALEntryStream.WALEntryStreamRuntimeException(Exception) - Constructor for exception org.apache.hadoop.hbase.replication.regionserver.WALEntryStream.WALEntryStreamRuntimeException
 
walFactory - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
WALFactory - Class in org.apache.hadoop.hbase.wal
Entry point for users of the Write Ahead Log.
WALFactory(Configuration, List<WALActionsListener>, String) - Constructor for class org.apache.hadoop.hbase.wal.WALFactory
 
WALFILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
WALFILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
WALFILE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
WALFILE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
walFs - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
walFS - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
 
WALInputFormat - Class in org.apache.hadoop.hbase.mapreduce
Simple InputFormat for WAL files.
WALInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
WALKey - Class in org.apache.hadoop.hbase.wal
A Key for an entry in the change log.
WALKey() - Constructor for class org.apache.hadoop.hbase.wal.WALKey
 
WALKey(byte[], TableName, long, long, UUID) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
 
WALKey(byte[], TableName) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
 
WALKey(byte[], TableName, long) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
 
WALKey(byte[], TableName, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
 
WALKey(byte[], TableName, long, long, List<UUID>, long, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
Create the log key for writing to somewhere.
WALKey(byte[], TableName, long, List<UUID>, long, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
Create the log key for writing to somewhere.
WALKey(byte[], TableName, long, long, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
Create the log key for writing to somewhere.
WALKey.Version - Enum in org.apache.hadoop.hbase.wal
 
WALLink - Class in org.apache.hadoop.hbase.io
WALLink describes a link to a WAL.
WALLink(Configuration, String, String) - Constructor for class org.apache.hadoop.hbase.io.WALLink
 
WALLink(Path, String, String) - Constructor for class org.apache.hadoop.hbase.io.WALLink
 
WALLink(Path, Path) - Constructor for class org.apache.hadoop.hbase.io.WALLink
 
WALObserver - Interface in org.apache.hadoop.hbase.coprocessor
It's provided to have a way for coprocessors to observe, rewrite, or skip WALEdits as they are being written to the WAL.
WALPlayer - Class in org.apache.hadoop.hbase.mapreduce
A tool to replay WAL files as a M/R job.
WALPlayer(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
WALPlayer.WALMapper - Class in org.apache.hadoop.hbase.mapreduce
A mapper that writes out Mutation to be directly applied to a running HBase instance.
WALPlayer.WALMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
 
WALPrettyPrinter - Class in org.apache.hadoop.hbase.wal
WALPrettyPrinter prints the contents of a given WAL with a variety of options affecting formatting and extent of content.
WALPrettyPrinter() - Constructor for class org.apache.hadoop.hbase.wal.WALPrettyPrinter
Basic constructor that simply initializes values to reasonable defaults.
WALPrettyPrinter(boolean, boolean, long, String, String, boolean, PrintStream) - Constructor for class org.apache.hadoop.hbase.wal.WALPrettyPrinter
Fully specified constructor.
WALProcedureStore - Class in org.apache.hadoop.hbase.procedure2.store.wal
WAL implementation of the ProcedureStore.
WALProcedureStore(Configuration, FileSystem, Path, WALProcedureStore.LeaseRecovery) - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
WALProcedureStore.LeaseRecovery - Interface in org.apache.hadoop.hbase.procedure2.store.wal
 
WALProcedureStore.SyncMetrics - Class in org.apache.hadoop.hbase.procedure2.store.wal
 
WALProcedureStore.SyncMetrics() - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
 
WALProvider - Interface in org.apache.hadoop.hbase.wal
The Write Ahead Log (WAL) stores all durable edits to the HRegion.
WALProvider.Writer - Interface in org.apache.hadoop.hbase.wal
 
walRollFinished() - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
For testing only
walRollRequestFinished() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
For testing
WALSplitter - Class in org.apache.hadoop.hbase.wal
This class is responsible for splitting up a bunch of regionserver commit log files that are no longer being written to, into new files, one per region for region to replay on startup.
WALSplitter.EntryBuffers - Class in org.apache.hadoop.hbase.wal
Class which accumulates edits and separates them into a buffer per region while simultaneously accounting RAM usage.
WALSplitter.EntryBuffers(WALSplitter.PipelineController, long) - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.EntryBuffers
 
WALSplitter.EntryBuffers(WALSplitter.PipelineController, long, boolean) - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.EntryBuffers
 
WALSplitter.MutationReplay - Class in org.apache.hadoop.hbase.wal
A struct used by getMutationsFromWALEntry
WALSplitter.MutationReplay(ClientProtos.MutationProto.MutationType, Mutation, long, long) - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.MutationReplay
 
WALSplitter.OutputSink - Class in org.apache.hadoop.hbase.wal
The following class is an abstraction class to provide a common interface to support both existing recovered edits file sink and region server WAL edits replay sink
WALSplitter.OutputSink(WALSplitter.PipelineController, WALSplitter.EntryBuffers, int) - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
WALSplitter.PipelineController - Class in org.apache.hadoop.hbase.wal
Contains some methods to control WAL-entries producer / consumer interactions
WALSplitter.PipelineController() - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.PipelineController
 
WALSplitter.RegionEntryBuffer - Class in org.apache.hadoop.hbase.wal
A buffer of some number of edits for a given region.
WALSplitter.SinkWriter - Class in org.apache.hadoop.hbase.wal
Class wraps the actual writer which writes data out and related statistics
WALSplitter.SinkWriter() - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.SinkWriter
 
WALSplitter.WriterThread - Class in org.apache.hadoop.hbase.wal
 
WALSplitterHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handles log splitting a wal
WALSplitterHandler(Server, SplitLogWorkerCoordination, SplitLogWorkerCoordination.SplitTaskDetails, CancelableProgressable, AtomicInteger, SplitLogWorker.TaskExecutor, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.WALSplitterHandler
 
WALUtil - Class in org.apache.hadoop.hbase.regionserver.wal
Helper methods to ease Region Server integration with the write ahead log.
warmupHRegion(HRegionInfo, HTableDescriptor, WAL, Configuration, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
 
warmupRegion(RpcController, AdminProtos.AdminService.BlockingInterface, HRegionInfo) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to warmup a region given a region name using admin protocol
warmupRegion(RpcController, AdminProtos.WarmupRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Wamrmup a region on this server.
WARN_THRESHOLD_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
 
WARN_THRESHOLD_COUNT_KEY - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
 
WARN_THRESHOLD_KEY - Static variable in class org.apache.hadoop.hbase.util.JvmPauseMonitor
 
wasExecuted() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
wasOperationAttemptedByServer() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
 
wasRegionOnDeadServerByMeta(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
watchAndCheckExists(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Watch the specified znode for delete/create/change events.
watcher - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
watcher - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
 
WeakObjectPool<K,V> - Class in org.apache.hadoop.hbase.util
A WeakReference based shared object pool.
WeakObjectPool(WeakObjectPool.ObjectFactory<K, V>) - Constructor for class org.apache.hadoop.hbase.util.WeakObjectPool
Creates a new pool with the default initial capacity (16) and the default concurrency level (16).
WeakObjectPool(WeakObjectPool.ObjectFactory<K, V>, int) - Constructor for class org.apache.hadoop.hbase.util.WeakObjectPool
Creates a new pool with the given initial capacity and the default concurrency level (16).
WeakObjectPool(WeakObjectPool.ObjectFactory<K, V>, int, int) - Constructor for class org.apache.hadoop.hbase.util.WeakObjectPool
Creates a new pool with the given initial capacity and the given concurrency level.
WeakObjectPool.ObjectFactory<K,V> - Interface in org.apache.hadoop.hbase.util
An ObjectFactory object is used to create new shared objects on demand.
webAppContext - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
webServer - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
WEEK_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
Seconds in a week
WHEEL_TIMER - Static variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
whichFanNode(byte) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
WHILE_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
WHILE Array
WHILE_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
WhileMatchFilter - Class in org.apache.hadoop.hbase.filter
WhileMatchFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
WHITESPACE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for whitespace
whoAmI(RpcController, AuthenticationProtos.WhoAmIRequest, RpcCallback<AuthenticationProtos.WhoAmIResponse>) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
 
width - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
WINDOWS - Static variable in class org.apache.hadoop.hbase.util.FSUtils
Set to true on Windows platforms
WINDOWS_PER_TIER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory
 
withBlockSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
withBloomType(BloomType) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
withBytesPerCheckSum(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
withChecksumType(ChecksumType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
withCompactedFiles(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
withComparator(KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
withComparator(KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
withCompression(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
withCompressTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
withCreateTime(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
withDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
withEncryptionContext(Encryption.Context) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
withFavoredNodes(InetSocketAddress[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
withFavoredNodes(InetSocketAddress[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
withFileContext(HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
withFileContext(HFileContext) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
withFilePath(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
withHBaseCheckSum(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
withHFileName(String) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
withIncludesMvcc(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
withIncludesTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
withinOrAfterTimeRange(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if the specified timestamp is within or after this TimeRange.
withinTimeRange(byte[], int) - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if the specified timestamp is within this TimeRange.
withinTimeRange(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if the specified timestamp is within this TimeRange.
withMaxKeyCount(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
withOutputDir(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
withOutputStream(FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
withPath(FileSystem, Path) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
withShouldDropCacheBehind(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
withShouldDropCacheBehind(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
withStartRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Set the start row of the scan.
withStartRow(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Set the start row of the scan.
withStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Set the stop row of the scan.
withStopRow(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Set the stop row of the scan.
withTimeRangeTracker(TimeRangeTracker) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
WORKER_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
Number fo threads for processing the thrift calls
workingDir - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
workingDirFs - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
wrap(byte[]) - Static method in class com.google.protobuf.HBaseZeroCopyByteString
Wraps a byte array in a ByteString without copying it.
wrap(byte[], int, int) - Static method in class com.google.protobuf.HBaseZeroCopyByteString
Wraps a subset of a byte array in a ByteString without copying it.
wrap(byte[]) - Static method in class org.apache.hadoop.hbase.util.ByteStringer
Wraps a byte array in a ByteString without copying it.
wrap(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteStringer
Wraps a subset of a byte array in a ByteString without copying it.
wrap(byte[]) - Static method in class org.apache.hadoop.hbase.util.ImmutableByteArray
 
wrapKey(Configuration, byte[], String) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
Protect a key by encrypting it with the secret key of the given subject.
wrapKey(Configuration, String, Key) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
Protect a key by encrypting it with the secret key of the given subject.
wrapped - Variable in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
Writables - Class in org.apache.hadoop.hbase.util
Utility class with methods for manipulating Writable objects
Writables() - Constructor for class org.apache.hadoop.hbase.util.Writables
 
WritableWithSize - Interface in org.apache.hadoop.hbase.io
An optional interface to 'size' writables.
write(Cell) - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
 
write(Cell) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueEncoder
 
write(Cell) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueEncoder
 
write(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
write(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
writing the compiled structure to the OutputStream
write(DataOutput) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
Writables are going away. Use HColumnDescriptor.toByteArray() instead.
write(DataOutput) - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Use protobuf serialization instead. See HRegionInfo.toByteArray() and HRegionInfo.toDelimitedByteArray()
write(DataOutput) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Writables are going away. Use MessageLite.toByteArray() instead.
write(int) - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
 
write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
 
write(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
write(byte[]) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
write(Cell) - Method in interface org.apache.hadoop.hbase.io.CellOutputStream
Implementation must copy the entire state of the Cell.
write(int) - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
 
write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
 
write(int) - Method in class org.apache.hadoop.hbase.io.DataOutputOutputStream
 
write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.DataOutputOutputStream
 
write(byte[]) - Method in class org.apache.hadoop.hbase.io.DataOutputOutputStream
 
write(Cell) - Method in class org.apache.hadoop.hbase.io.encoding.NoneEncoder
 
write(Cell) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
 
write(DataOutput) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
 
write(ByteBuffer) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
 
write(ByteBuffer, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
Transfers data from the given byte buffer to the buffer array
write(ByteBuffer, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
Transfers data from the given byte buffer to file
write(ByteBuffer, long) - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
Transfers data from the given byte buffer to IOEngine
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
write(FileSystem, Path) - Method in class org.apache.hadoop.hbase.io.Reference
 
write(KeyValue, DataOutput) - Static method in class org.apache.hadoop.hbase.KeyValue
Write out a KeyValue in the manner in which we used to when KeyValue was a Writable.
write(ImmutableBytesWritable, Put) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable
 
write(ImmutableBytesWritable, Mutation) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
Writes an action (Put or Delete) to the specified table.
write(KEY, Mutation) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
Writes a key/value pair into the table.
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Writes the field values to the output.
write(int) - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
 
write(byte[], int, int) - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
Don't use these Writables methods. Use PB instead.
write(Cell) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.EnsureKvEncoder
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
write(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
 
write(byte[]) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
 
write(byte[], int, int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
 
write(OutputStream) - Method in class org.apache.hadoop.hbase.rest.ProtobufStreamingUtil
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.security.access.Permission
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.security.access.UserPermission
 
write(DataOutput) - Method in enum org.apache.hadoop.hbase.security.AuthMethod
Write to out
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.hadoop.hbase.security.SaslWrapHandler
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
write(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
write(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
write(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndMutate_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.existsAll_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getAllRegionLocations_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getRegionLocation_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionInfo
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
 
write(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
write(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TServerName
 
write(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
write(int) - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Writes the byte to the output stream after converting to/from Base64 notation.
write(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Calls Base64.Base64OutputStream.write(int) repeatedly until len bytes are written.
write(OutputStream, ByteRange) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
 
write(OutputStream, ByteRange, int) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
 
write(String, String) - Method in interface org.apache.hadoop.hbase.util.JSONBean.Writer
 
write(MBeanServer, ObjectName, String, boolean) - Method in interface org.apache.hadoop.hbase.util.JSONBean.Writer
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.append_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.atomicIncrement_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.checkAndPut_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.compact_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.createTable_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAll_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRow_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRowTs_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllTs_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteTable_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.disableTable_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.enableTable_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.get_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getColumnDescriptors_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRegionInfo_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRow_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowOrBefore_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRows_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsTs_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumns_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumnsTs_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowTs_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumns_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumnsTs_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableNames_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableRegions_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVer_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVerTs_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.increment_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.incrementRows_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.isTableEnabled_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.majorCompact_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRow_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRows_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowsTs_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowTs_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerClose_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGet_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGetList_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpen_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenTs_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithPrefix_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithScan_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStop_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStopTs_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.append_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndDelete_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndMutate_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndPut_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.closeScanner_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteMultiple_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteSingle_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.exists_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.existsAll_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.get_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getAllRegionLocations_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getMultiple_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getRegionLocation_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerResults_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerRows_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.increment_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.mutateRow_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.openScanner_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.put_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.putMultiple_call
 
WRITE_BUFFER_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
WRITE_BUFFER_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
 
WRITE_LOCK_CHILD_NODE_PREFIX - Static variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
ZNode prefix used by processes acquiring writer locks
WRITE_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
WRITE_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
WRITE_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
WRITE_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
WRITE_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
WRITE_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
WRITE_REQUEST_RATE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
WRITE_REQUEST_RATE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
writeAt(int, int) - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
 
writeBloom(DataOutput) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
Writes just the bloom filter to the output array
writeBufferSize(long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
Override the write buffer size specified by the provided Connection's Configuration instance, via the configuration key hbase.client.write.buffer.
writeBulkLoadMarkerAndSync(WAL, HTableDescriptor, HRegionInfo, WALProtos.BulkLoadDescriptor, MultiVersionConcurrencyControl) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
Write a log marker that a bulk load has succeeded and is about to be committed.
writeByteArray(byte[], int, byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int, Tag[]) - Static method in class org.apache.hadoop.hbase.KeyValue
Write KeyValue format into the provided byte array.
writeByteArray(DataOutput, byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write byte-array with a WritableableUtils.vint prefix.
writeByteArray(DataOutput, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write byte-array to out with a vint length prefix.
writeByteArray(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Write byte-array from src to tgt with a vint length prefix.
writeBytes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
 
writeBytes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
 
writeBytes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
writeBytes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
writeBytes(int, long, byte[], int) - Static method in class org.apache.hadoop.hbase.util.vint.UFIntTool
 
writeBytes(int, long, OutputStream) - Static method in class org.apache.hadoop.hbase.util.vint.UFIntTool
 
writeBytes(int, OutputStream) - Static method in class org.apache.hadoop.hbase.util.vint.UVIntTool
 
writeBytes(long, OutputStream) - Static method in class org.apache.hadoop.hbase.util.vint.UVLongTool
 
writeCellTypes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
writeCompactionMarker(WAL, HTableDescriptor, HRegionInfo, WALProtos.CompactionDescriptor, MultiVersionConcurrencyControl) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
Write the marker that a compaction has succeeded and is about to be committed.
writeDelete(ByteSlot, long) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
 
writeDelete(ByteSlot, Procedure, long[]) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
 
writeEntry(ByteSlot, ProcedureProtos.ProcedureWALEntry.Type, Procedure, Procedure[]) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
 
writeFamilyNodeOffsets(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
The following methods write data for each cell in the row, mostly consisting of indexes or offsets into the timestamp/column data structures that are written in the middle of the block.
writeFan(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
UVInt: numFanBytes/fanOut bytes: each fan byte
writeFileInfo(FixedFileTrailer, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Sets the file info offset in the trailer, finishes up populating fields in the file info, and writes the file info into the given data output.
writeFlatKey(Cell, DataOutputStream) - Static method in class org.apache.hadoop.hbase.CellUtil
Writes the Cell's key part as it would have serialized in a KeyValue.
writeFlushMarker(WAL, HTableDescriptor, HRegionInfo, WALProtos.FlushDescriptor, boolean, MultiVersionConcurrencyControl) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
Write a flush marker indicating a start / abort or a complete of a region flush
writeHeader(OutputStream, ProcedureProtos.ProcedureWALHeader) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
 
writeIdInBytes(OutputStream) - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Writes id in bytes.
writeIdInBytes(byte[], int) - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Writes id bytes to the given array starting from offset.
writeIndexBlocks(FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Writes the root level and intermediate levels of the block index into the output stream, generating the tree from bottom up.
writeInlineBlock(DataOutput) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Write out the current inline index block.
writeInlineBlock(DataOutput) - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
Writes the block to the provided stream.
writeInlineBlock(DataOutput) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
 
writeInsert(ByteSlot, Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
 
writeInsert(ByteSlot, Procedure, Procedure[]) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
 
writeInt(int) - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
Writes an int to the underlying output stream as four bytes, high byte first.
writeInt(OutputStream, int) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
 
writeLock(byte[]) - Method in interface org.apache.hadoop.hbase.InterProcessReadWriteLock
Obtain a write lock containing given metadata.
writeLock(TableName, String) - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
 
writeLock(TableName, String) - Method in class org.apache.hadoop.hbase.master.TableLockManager
Returns a TableLock for locking the table for exclusive access
writeLock(byte[]) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessReadWriteLock
Obtain a write lock containing given metadata.
writeLong(OutputStream, long) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
 
writeMapAsString(Map<String, Object>) - Static method in class org.apache.hadoop.hbase.util.JsonMapper
 
writeMvccVersionIndexes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
writeMyEphemeralNodeOnDisk(String) - Static method in class org.apache.hadoop.hbase.ZNodeClearer
Logs the errors without failing on exception.
writeNamespaceToZooKeeper(String, TableAuthManager.PermissionCache<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
writeNextRowTrieNodeOffsets(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
If a branch or a nub, the last thing we append are the UFInt offsets to the child row nodes.
writeNumCells(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
UVInt: numCells, the number of cells in this row which will be 0 for branch nodes
writeObjectAsString(Object) - Static method in class org.apache.hadoop.hbase.util.JsonMapper
 
writePermissionsAsBytes(ListMultimap<String, TablePermission>, Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
Writes a set of permissions as Writable instances and returns the resulting byte array.
writeQualifierNodeOffsets(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
writer - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
 
writeRawVInt32(OutputStream, int) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
 
WriterBase - Class in org.apache.hadoop.hbase.regionserver.wal
Context used by our wal dictionary compressor.
WriterBase() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WriterBase
 
writeRegionEventMarker(WAL, HTableDescriptor, HRegionInfo, WALProtos.RegionEventDescriptor, MultiVersionConcurrencyControl) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
Write a region open marker indicating that the region is opened
writeRegionSequenceIdFile(FileSystem, Path, long, long) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
Create a file with name as region open sequence id
writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
WRITEREQUESTSCOUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
writerFactory - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
Factory that is used to produce single StoreFile.Writer-s
writeRowKeyExcludingCommon(Cell, short, int, DataOutputStream) - Static method in class org.apache.hadoop.hbase.CellUtil
Write rowkey excluding the common part.
writeRowToken(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
UVInt: tokenWidth bytes: token
writers() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
 
writers() - Method in class org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
 
writers() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
writers - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
writersClosed - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
writerThreads - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
writeScanMetrics() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Publish the scan metrics.
writeShort(OutputStream, short) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
 
writeSingleLevelIndex(DataOutput, String) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Writes the block index data as a single level only.
WriteSinkCoprocessor - Class in org.apache.hadoop.hbase.tool
This coprocessor 'shallows' all the writes.
WriteSinkCoprocessor() - Constructor for class org.apache.hadoop.hbase.tool.WriteSinkCoprocessor
 
writeSnapshotInfo(HBaseProtos.SnapshotDescription, Path, FileSystem) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Write the snapshot description into the working directory of a snapshot
writeStringFixedSize(DataOutput, String, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Writes a string as a fixed-size field, padded with zeros.
writeTableToZooKeeper(TableName, TableAuthManager.PermissionCache<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
writeTagNodeOffsets(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
writeTime - Variable in class org.apache.hadoop.hbase.wal.WALKey
 
writeTimestampIndexes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
writeTo(OutputStream) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
Writes the complete contents of this byte buffer output stream to the specified output stream argument.
writeTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
writeTo(OutputStream) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
writeTo(OutputStream) - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties.Property
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacePropertiesMessage.NamespaceProperties
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.NamespacesMessage.Namespaces
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
writeTo(Object, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class org.apache.hadoop.hbase.rest.provider.producer.PlainTextMessageBodyProducer
 
writeTo(ProtobufMessageHandler, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class org.apache.hadoop.hbase.rest.provider.producer.ProtobufMessageBodyProducer
 
writeTo(PrintWriter) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
 
writeTo(PrintStream) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
 
writeToStream(OutputStream) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
 
writeToWAL - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
writeToZookeeper(byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
Write a table's access controls to the permissions mirror in zookeeper
writeToZookeeper(byte[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
 
writeToZookeeper(byte[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
Write a labels mirror or user auths mirror into zookeeper
writeTrailer(FSDataOutputStream, ProcedureStoreTracker) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
 
writeUpdate(ByteSlot, Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
 
writeValueLengths(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
writeValueOffsets(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
writeVariableBytesToOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
writeVLong(ByteBuffer, long) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Similar to WritableUtils.writeVLong(java.io.DataOutput, long), but writes to a ByteBuffer.
writeWithRepeatRow(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
Add a Cell to the output stream but repeat the previous row.
writeXml(OutputStream) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
WRITTEN_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
WRITTEN_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
WrongRegionException - Exception in org.apache.hadoop.hbase.regionserver
Thrown when a request contains a key which is not part of this region
WrongRegionException() - Constructor for exception org.apache.hadoop.hbase.regionserver.WrongRegionException
constructor
WrongRegionException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.WrongRegionException
Constructor
WrongRowIOException - Exception in org.apache.hadoop.hbase.client
 
WrongRowIOException(String) - Constructor for exception org.apache.hadoop.hbase.client.WrongRowIOException
 
WrongVersionException - Exception in org.apache.hadoop.hbase.ipc
 
WrongVersionException() - Constructor for exception org.apache.hadoop.hbase.ipc.WrongVersionException
 
WrongVersionException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.WrongVersionException
 
WrongVersionException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.WrongVersionException
 
WWW_AUTHENTICATE - Static variable in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
 

Y

YammerHistogramUtils - Class in org.apache.hadoop.hbase.util
Utility functions for working with Yammer Metrics.
yield(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
yield(Procedure) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
The procedure can't run at the moment.
yield(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
 
YouAreDeadException - Exception in org.apache.hadoop.hbase
This exception is thrown by the master when a region server reports and is already being processed as dead.
YouAreDeadException(String) - Constructor for exception org.apache.hadoop.hbase.YouAreDeadException
 

Z

ZERO - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for Zero
ZERO - Static variable in class org.apache.hadoop.hbase.hbtop.field.Size
 
zero(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Fill given array with zeros.
zero(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Fill given array with zeros at the specified position.
ZERO_L - Static variable in class org.apache.hadoop.hbase.HConstants
long constant for zero
zeroCopyGetBytes(ByteString) - Static method in class com.google.protobuf.HBaseZeroCopyByteString
Extracts the byte array from the given ByteString without copy.
ZEROES - Static variable in class org.apache.hadoop.hbase.HConstants
 
ZK_CFG_PROPERTY_PREFIX - Static variable in class org.apache.hadoop.hbase.HConstants
Common prefix of ZooKeeper configuration properties
ZK_CFG_PROPERTY_PREFIX_LEN - Static variable in class org.apache.hadoop.hbase.HConstants
 
ZK_CLIENT_KERBEROS_PRINCIPAL - Static variable in class org.apache.hadoop.hbase.HConstants
 
ZK_CLIENT_KEYTAB_FILE - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration keys for programmatic JAAS configuration for secured ZK interaction
ZK_SERVER_KERBEROS_PRINCIPAL - Static variable in class org.apache.hadoop.hbase.HConstants
 
ZK_SERVER_KEYTAB_FILE - Static variable in class org.apache.hadoop.hbase.HConstants
 
ZK_SESSION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for ZooKeeper session timeout
ZkAclReset - Class in org.apache.hadoop.hbase.zookeeper
You may add the jaas.conf option -Djava.security.auth.login.config=/PATH/jaas.conf You may also specify -D to set options "hbase.zookeeper.quorum" (it should be in hbase-site.xml) "zookeeper.znode.parent" (it should be in hbase-site.xml) Use -set-acls to set the ACLs, no option to erase ACLs
ZkAclReset() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZkAclReset
 
ZKAssign - Class in org.apache.hadoop.hbase.zookeeper
Utility class for doing region assignment in ZooKeeper.
ZKAssign() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKAssign
 
ZkCloseRegionCoordination - Class in org.apache.hadoop.hbase.coordination
ZK-based implementation of CloseRegionCoordination.
ZkCloseRegionCoordination(CoordinatedStateManager, ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination
 
ZkCloseRegionCoordination.ZkCloseRegionDetails - Class in org.apache.hadoop.hbase.coordination
ZK-based implementation.
ZkCloseRegionCoordination.ZkCloseRegionDetails() - Constructor for class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
 
ZkCloseRegionCoordination.ZkCloseRegionDetails(boolean, int) - Constructor for class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
 
ZKClusterId - Class in org.apache.hadoop.hbase.zookeeper
Publishes and synchronizes a unique identifier specific to a given HBase cluster.
ZKClusterId(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
ZKConfig - Class in org.apache.hadoop.hbase.zookeeper
Utility methods for reading, and building the ZooKeeper configuration.
ZKConfig.ZKClusterKey - Class in org.apache.hadoop.hbase.zookeeper
 
ZkCoordinatedStateManager - Class in org.apache.hadoop.hbase.coordination
ZooKeeper-based implementation of CoordinatedStateManager.
ZkCoordinatedStateManager() - Constructor for class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
 
ZKDataMigrator - Class in org.apache.hadoop.hbase.util
Tool to migrate zookeeper data of older hbase versions(<0.95.0) to PB.
ZKDataMigrator() - Constructor for class org.apache.hadoop.hbase.util.ZKDataMigrator
 
zkEventWorkersSubmit(AssignmentManager.RegionRunnable) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Submit a task, ensuring that there is only one task at a time that working on a given region.
ZKInterProcessLockBase - Class in org.apache.hadoop.hbase.zookeeper.lock
ZooKeeper based HLock implementation.
ZKInterProcessLockBase(ZooKeeperWatcher, String, byte[], InterProcessLock.MetadataHandler, String) - Constructor for class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Called by implementing classes.
ZKInterProcessLockBase.AcquiredLock - Class in org.apache.hadoop.hbase.zookeeper.lock
Represents information about a lock held by this thread.
ZKInterProcessLockBase.AcquiredLock(String, int) - Constructor for class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.AcquiredLock
Store information about a lock.
ZKInterProcessLockBase.ZNodeComparator - Class in org.apache.hadoop.hbase.zookeeper.lock
 
ZKInterProcessReadLock - Class in org.apache.hadoop.hbase.zookeeper.lock
ZooKeeper based read lock: does not exclude other read locks, but excludes and is excluded by write locks.
ZKInterProcessReadLock(ZooKeeperWatcher, String, byte[], InterProcessLock.MetadataHandler) - Constructor for class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessReadLock
 
ZKInterProcessReadWriteLock - Class in org.apache.hadoop.hbase.zookeeper.lock
ZooKeeper based implementation of InterProcessReadWriteLock.
ZKInterProcessReadWriteLock(ZooKeeperWatcher, String, InterProcessLock.MetadataHandler) - Constructor for class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessReadWriteLock
Creates a DistributedReadWriteLock instance.
ZKInterProcessWriteLock - Class in org.apache.hadoop.hbase.zookeeper.lock
ZooKeeper based write lock:
ZKInterProcessWriteLock(ZooKeeperWatcher, String, byte[], InterProcessLock.MetadataHandler) - Constructor for class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessWriteLock
 
zkkey - Static variable in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
 
ZKLeaderManager - Class in org.apache.hadoop.hbase.zookeeper
Deprecated.
Not used
ZKLeaderManager(ZooKeeperWatcher, String, byte[], Stoppable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
 
ZKNamespaceManager - Class in org.apache.hadoop.hbase
Class servers two purposes: 1.
ZKNamespaceManager(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.ZKNamespaceManager
 
ZkOpenRegionCoordination - Class in org.apache.hadoop.hbase.coordination
ZK-based implementation of OpenRegionCoordination.
ZkOpenRegionCoordination(CoordinatedStateManager, ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
 
ZkOpenRegionCoordination.ZkOpenRegionDetails - Class in org.apache.hadoop.hbase.coordination
ZK-based implementation.
ZkOpenRegionCoordination.ZkOpenRegionDetails() - Constructor for class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
 
ZkOpenRegionCoordination.ZkOpenRegionDetails(int) - Constructor for class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
 
ZKPermissionWatcher - Class in org.apache.hadoop.hbase.security.access
Handles synchronization of access control list entries and updates throughout all nodes in the cluster.
ZKPermissionWatcher(ZooKeeperWatcher, TableAuthManager, Configuration) - Constructor for class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
 
ZKProcedureCoordinatorRpcs - Class in org.apache.hadoop.hbase.procedure
ZKProcedureCoordinatorRpcs(ZooKeeperWatcher, String, String) - Constructor for class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
 
ZKProcedureMemberRpcs - Class in org.apache.hadoop.hbase.procedure
ZooKeeper based controller for a procedure member.
ZKProcedureMemberRpcs(ZooKeeperWatcher, String) - Constructor for class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
Must call ZKProcedureMemberRpcs.start(String, ProcedureMember) before this can be used.
ZKProcedureUtil - Class in org.apache.hadoop.hbase.procedure
This is a shared ZooKeeper-based znode management utils for distributed procedure.
ZKProcedureUtil(ZooKeeperWatcher, String) - Constructor for class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
Top-level watcher/controller for procedures across the cluster.
ZkRegionMergeCoordination - Class in org.apache.hadoop.hbase.coordination
 
ZkRegionMergeCoordination(CoordinatedStateManager, ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
 
ZkRegionMergeCoordination.ZkRegionMergeDetails - Class in org.apache.hadoop.hbase.coordination
ZK-based implementation.
ZkRegionMergeCoordination.ZkRegionMergeDetails() - Constructor for class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination.ZkRegionMergeDetails
 
ZKSecretWatcher - Class in org.apache.hadoop.hbase.security.token
Synchronizes token encryption keys across cluster nodes.
ZKSecretWatcher(Configuration, ZooKeeperWatcher, AuthenticationTokenSecretManager) - Constructor for class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
ZKServerTool - Class in org.apache.hadoop.hbase.zookeeper
Tool for reading ZooKeeper servers from HBase XML configuration and producing a line-by-line list for use by bash scripts.
ZKServerTool() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKServerTool
 
ZKSplitLog - Class in org.apache.hadoop.hbase.zookeeper
Common methods and attributes used by SplitLogManager and SplitLogWorker running distributed splitting of WAL logs.
ZKSplitLog() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
ZKSplitLogManagerCoordination - Class in org.apache.hadoop.hbase.coordination
ZooKeeper based implementation of SplitLogManagerCoordination
ZKSplitLogManagerCoordination(CoordinatedStateManager, ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
ZKSplitLogManagerCoordination.CreateAsyncCallback - Class in org.apache.hadoop.hbase.coordination
Asynchronous handler for zk create node results.
ZKSplitLogManagerCoordination.CreateAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateAsyncCallback
 
ZKSplitLogManagerCoordination.CreateRescanAsyncCallback - Class in org.apache.hadoop.hbase.coordination
Asynchronous handler for zk create RESCAN-node results.
ZKSplitLogManagerCoordination.CreateRescanAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateRescanAsyncCallback
 
ZKSplitLogManagerCoordination.DeleteAsyncCallback - Class in org.apache.hadoop.hbase.coordination
Asynchronous handler for zk delete node results.
ZKSplitLogManagerCoordination.DeleteAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.DeleteAsyncCallback
 
ZKSplitLogManagerCoordination.GetDataAsyncCallback - Class in org.apache.hadoop.hbase.coordination
Asynchronous handler for zk get-data-set-watch on node results.
ZKSplitLogManagerCoordination.GetDataAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.GetDataAsyncCallback
 
ZKSplitLogManagerCoordination.TaskFinisher - Interface in org.apache.hadoop.hbase.coordination
SplitLogManager can use objects implementing this interface to finish off a partially done task by SplitLogWorker.
ZKSplitLogManagerCoordination.TaskFinisher.Status - Enum in org.apache.hadoop.hbase.coordination
status that can be returned finish()
ZKSplitLogManagerCoordination.ZkSplitLogManagerDetails - Class in org.apache.hadoop.hbase.coordination
 
ZkSplitLogWorkerCoordination - Class in org.apache.hadoop.hbase.coordination
ZooKeeper based implementation of SplitLogWorkerCoordination It listen for changes in ZooKeeper and
ZkSplitLogWorkerCoordination(ZkCoordinatedStateManager, ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
 
ZkSplitLogWorkerCoordination.ZkSplitTaskDetails - Class in org.apache.hadoop.hbase.coordination
When ZK-based implementation wants to complete the task, it needs to know task znode and current znode cversion (needed for subsequent update operation).
ZkSplitLogWorkerCoordination.ZkSplitTaskDetails() - Constructor for class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
 
ZkSplitLogWorkerCoordination.ZkSplitTaskDetails(String, MutableInt) - Constructor for class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
 
ZKSplitTransactionCoordination - Class in org.apache.hadoop.hbase.coordination
 
ZKSplitTransactionCoordination(CoordinatedStateManager, ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
 
ZKSplitTransactionCoordination.ZkSplitTransactionDetails - Class in org.apache.hadoop.hbase.coordination
ZK-based implementation.
ZKSplitTransactionCoordination.ZkSplitTransactionDetails() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination.ZkSplitTransactionDetails
 
ZKTableArchiveClient - Class in org.apache.hadoop.hbase.backup.example
Example class for how to use the table archiving coordinated via zookeeper
ZKTableArchiveClient(Configuration, ClusterConnection) - Constructor for class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
 
ZKTableStateClientSideReader - Class in org.apache.hadoop.hbase.zookeeper
Non-instantiable class that provides helper functions to learn about HBase table state for code running on client side (hence, not having access to consensus context).
ZKTableStateManager - Class in org.apache.hadoop.hbase.zookeeper
Implementation of TableStateManager which reads, caches and sets state up in ZooKeeper.
ZKTableStateManager(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
 
ZKUtil - Class in org.apache.hadoop.hbase.zookeeper
Internal HBase utility class for ZooKeeper.
ZKUtil() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
ZKUtil.NodeAndData - Class in org.apache.hadoop.hbase.zookeeper
Deprecated.
Unused
ZKUtil.NodeAndData(String, byte[]) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
Deprecated.
 
ZKUtil.ZKUtilOp - Class in org.apache.hadoop.hbase.zookeeper
Represents an action taken by ZKUtil, e.g.
ZKUtil.ZKUtilOp.CreateAndFailSilent - Class in org.apache.hadoop.hbase.zookeeper
ZKUtilOp representing createAndFailSilent in ZooKeeper (attempt to create node, ignore error if already exists)
ZKUtil.ZKUtilOp.DeleteNodeFailSilent - Class in org.apache.hadoop.hbase.zookeeper
ZKUtilOp representing deleteNodeFailSilent in ZooKeeper (attempt to delete node, ignore error if node doesn't exist)
ZKUtil.ZKUtilOp.SetData - Class in org.apache.hadoop.hbase.zookeeper
ZKUtilOp representing setData in ZooKeeper
ZKVisibilityLabelWatcher - Class in org.apache.hadoop.hbase.security.visibility
A zk watcher that watches the labels table znode.
ZKVisibilityLabelWatcher(ZooKeeperWatcher, VisibilityLabelsCache, Configuration) - Constructor for class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
 
zkWatcher - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
 
ZNODE_PATH_SEPARATOR - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
ZNodeClearer - Class in org.apache.hadoop.hbase
Contains a set of methods for the collaboration between the start/stop scripts and the servers.
zooKeeper - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
zookeeper - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the client port that the zookeeper listens on
ZOOKEEPER_CONFIG_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Name of ZooKeeper config file in conf/ directory.
ZOOKEEPER_DATA_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the ZK data directory
ZOOKEEPER_MAX_CLIENT_CNXNS - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the limit on concurrent client-side zookeeper connections
ZOOKEEPER_QUORUM - Static variable in class org.apache.hadoop.hbase.HConstants
Name of ZooKeeper quorum configuration parameter.
ZOOKEEPER_QUORUM_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
ZOOKEEPER_QUORUM_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
ZOOKEEPER_QUORUM_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
ZOOKEEPER_QUORUM_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
ZOOKEEPER_RECOVERABLE_WAITTIME - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the wait time for the recoverable zookeeper
ZOOKEEPER_TICK_TIME - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the ZK tick time
ZOOKEEPER_USEMULTI - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for whether to use ZK.multi
ZOOKEEPER_ZNODE_PARENT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the root dir in ZK for this cluster
ZOOKEEPER_ZNODE_REPLICATION_HFILE_REFS_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
ZOOKEEPER_ZNODE_REPLICATION_HFILE_REFS_KEY - Static variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
 
ZooKeeperConnectionException - Exception in org.apache.hadoop.hbase
Thrown if the client can't connect to ZooKeeper.
ZooKeeperConnectionException() - Constructor for exception org.apache.hadoop.hbase.ZooKeeperConnectionException
 
ZooKeeperConnectionException(String) - Constructor for exception org.apache.hadoop.hbase.ZooKeeperConnectionException
 
ZooKeeperConnectionException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.ZooKeeperConnectionException
Constructor taking another exception.
ZooKeeperListener - Class in org.apache.hadoop.hbase.zookeeper
Base class for internal listeners of ZooKeeper events.
ZooKeeperListener(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
Construct a ZooKeeper event listener.
ZooKeeperMainServer - Class in org.apache.hadoop.hbase.zookeeper
Tool for running ZookeeperMain from HBase by reading a ZooKeeper server from HBase XML configuration.
ZooKeeperMainServer() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZooKeeperMainServer
 
ZooKeeperNodeTracker - Class in org.apache.hadoop.hbase.zookeeper
Tracks the availability and value of a single ZooKeeper node.
ZooKeeperNodeTracker(ZooKeeperWatcher, String, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Constructs a new ZK node tracker.
ZooKeeperScanPolicyObserver - Class in org.apache.hadoop.hbase.coprocessor.example
This is an example showing how a RegionObserver could configured via ZooKeeper in order to control a Region compaction, flush, and scan policy.
ZooKeeperScanPolicyObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
 
ZooKeeperWatcher - Class in org.apache.hadoop.hbase.zookeeper
Acts as the single ZooKeeper Watcher.
ZooKeeperWatcher(Configuration, String, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Instantiate a ZooKeeper connection and watcher.
ZooKeeperWatcher(Configuration, String, Abortable, boolean) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Instantiate a ZooKeeper connection and watcher.

_

__getBlockcache() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
__getBlocksize() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
__getBloomfilter() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
__getCompression() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
__getInMemory() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
__getIsMeta() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
__getIsRoot() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
__getReadOnly() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
__getTTL() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
__getVersions() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
__jamon_setOptionalArguments(TaskMonitorTmpl.ImplData) - Static method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmplImpl
 
__jamon_setOptionalArguments(AssignmentManagerStatusTmpl.ImplData) - Static method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmplImpl
 
__jamon_setOptionalArguments(BackupMasterStatusTmpl.ImplData) - Static method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmplImpl
 
__jamon_setOptionalArguments(MasterStatusTmpl.ImplData) - Static method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmplImpl
 
__jamon_setOptionalArguments(RegionServerListTmpl.ImplData) - Static method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmplImpl
 
__jamon_setOptionalArguments(BlockCacheTmpl.ImplData) - Static method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmplImpl
 
__jamon_setOptionalArguments(BlockCacheViewTmpl.ImplData) - Static method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmplImpl
 
__jamon_setOptionalArguments(RegionListTmpl.ImplData) - Static method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmplImpl
 
__jamon_setOptionalArguments(RSStatusTmpl.ImplData) - Static method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmplImpl
 
__jamon_setOptionalArguments(ServerMetricsTmpl.ImplData) - Static method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmplImpl
 
__setBlockcache(boolean) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
__setBlocksize(int) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
__setBloomfilter(String) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
__setCompression(String) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
__setInMemory(boolean) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
__setIsMeta(boolean) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
__setIsRoot(boolean) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
__setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
__setTTL(int) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
__setVersions(int) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
_jspService(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.generated.regionserver.region_jsp
 
_jspService(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.generated.regionserver.regionserver_jsp
 
_jspService(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.generated.regionserver.storeFile_jsp
 
_jspService(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.generated.rest.rest_jsp
 
_jspService(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.generated.thrift.thrift_jsp
 
A B C D E F G H I J K L M N O P Q R S T U V W Y Z _ 

Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.