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

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 class org.apache.hadoop.hbase.client.HBaseAdmin
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.master.HMaster
 
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(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.master.ReplicationLogCleaner
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
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.zookeeper.ZooKeeperNodeTracker
Used to abort if a fatal error occurs
abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
abortCacheFlush(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
Abort a cache flush.
abortProcedure(String, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
Abort the procedure with the given name
abortRequested - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
abortServer(String, Server, CoprocessorEnvironment, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
abortServer(CoprocessorEnvironment, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
abortServer(CoprocessorEnvironment, Throwable) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
abortServer(CoprocessorEnvironment, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
abortWriter(StoreFile.Writer) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
abortZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
absoluteValueOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
AbstractClientScanner - Class in org.apache.hadoop.hbase.client
Helper class for custom client scanners.
AbstractClientScanner() - Constructor for class org.apache.hadoop.hbase.client.AbstractClientScanner
 
AbstractHBaseTool - Class in org.apache.hadoop.hbase.util
Common base class used for HBase command-line tools.
AbstractHBaseTool() - Constructor for class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
AbstractHFileReader - Class in org.apache.hadoop.hbase.io.hfile
Common functionality needed by all versions of HFile readers.
AbstractHFileReader(Path, FixedFileTrailer, FSDataInputStream, long, boolean, CacheConfig) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
AbstractHFileReader(Path, FixedFileTrailer, FSDataInputStream, FSDataInputStream, long, boolean, CacheConfig, HFileSystem) - 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, int, Compression.Algorithm, HFileDataBlockEncoder, KeyValue.KeyComparator) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
accept(Path) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter
 
accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.DirFilter
 
accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.FamilyDirFilter
 
accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.HFileFilter
 
accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.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.CachedBlock
Block has been accessed.
AccessController - Class in org.apache.hadoop.hbase.security.access
Provides basic authorization checks for data access and administrative operations.
AccessController() - Constructor for class org.apache.hadoop.hbase.security.access.AccessController
 
AccessControlLists - Class in org.apache.hadoop.hbase.security.access
Maintains lists of permission grants to users and groups to allow for authorization checks by AccessController.
AccessControlLists() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlLists
 
AccessControlProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.AccessControlService - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.AccessControlService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
 
AccessControlProtos.AccessControlService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.AccessControlService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.AccessControlService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.CheckPermissionsRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.CheckPermissionsRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.CheckPermissionsRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.CheckPermissionsResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.CheckPermissionsResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.CheckPermissionsResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.GrantRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.GrantRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.GrantRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.GrantResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.GrantResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.GrantResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.Permission - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.Permission.Action - Enum in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.Permission.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.PermissionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.RevokeRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.RevokeRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.RevokeRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.RevokeResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.RevokeResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.RevokeResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserPermission - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserPermission.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserPermissionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserPermissionsRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserPermissionsRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserPermissionsRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserPermissionsResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserPermissionsResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserPermissionsResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserTablePermissions - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserTablePermissions.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserTablePermissions.UserPermissions - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserTablePermissions.UserPermissions.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserTablePermissions.UserPermissionsOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessControlProtos.UserTablePermissionsOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AccessDeniedException - Exception in org.apache.hadoop.hbase.exceptions
Exception thrown by access-related methods.
AccessDeniedException() - Constructor for exception org.apache.hadoop.hbase.exceptions.AccessDeniedException
 
AccessDeniedException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.exceptions.AccessDeniedException
 
AccessDeniedException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.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.AccessControlLists
 
ACL_TABLE_NAME_STR - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
Internal storage table for access control lists
ACL_TABLEDESC - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
Table descriptor for ACL internal table
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.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
 
acquiredLock - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
 
acquiredZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
acquireLock(K) - Method in class org.apache.hadoop.hbase.util.KeyLocker
Return a lock for the given key.
acquireLocks(Set<K>) - Method in class org.apache.hadoop.hbase.util.KeyLocker
Acquire locks for a set of keys.
Action<R> - Class in org.apache.hadoop.hbase.client
A Get, Put or Delete associated with it's region.
Action(Row, int) - Constructor for class org.apache.hadoop.hbase.client.Action
 
ACTION_BY_CODE - Static variable in class org.apache.hadoop.hbase.security.access.Permission
 
ACTION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
ACTION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
actions - Variable in class org.apache.hadoop.hbase.client.MultiAction
 
actions - Variable in class org.apache.hadoop.hbase.security.access.Permission
 
actualErrorRate() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
Computes the error rate for this Bloom filter, taking into account the actual number of hash functions and keys inserted.
actualErrorRate(long, long, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
Computes the actual error rate for the given number of elements, number of bits, and number of hash functions.
add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
Add the specified column and value to this Append operation.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Append
Add column and value to this Append operation.
add(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
add(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
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[], Pair<Integer, Object>) - Method in class org.apache.hadoop.hbase.client.MultiResponse
Add the pair to the container, grouped by the regionName
add(byte[], int, Object) - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value to this Put operation.
add(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.
add(KeyValue) - 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(CachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlockQueue
Attempt to add the specified cached block to this queue.
add(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
Adds the server to the dead server list if it's not there already.
add(String) - Method in class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
Append the given message to this buffer, automatically evicting older messages until the desired memory limit is achieved.
add(byte[], int, int, long, byte) - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
Add the specified KeyValue to the list of deletes to check against for this row operation.
add(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
add(byte[], int, int, long, byte) - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
Add the specified KeyValue to the list of deletes to check against for this row operation.
add(KeyValue) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Adds a value to the memstore
add(KeyValue) - 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(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(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[], int, int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
Adds a Bloom filter key.
add(HTableDescriptor) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
 
add(R) - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
Adds an edge to the split calculator
add(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
add(long) - Method in interface org.apache.hadoop.metrics2.MetricHistogram
Add a single value to a histogram's stream of values.
addAction(AccessControlProtos.Permission.Action) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
addAction(ClientProtos.MultiAction) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
addAction(int, ClientProtos.MultiAction) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
addAction(ClientProtos.MultiAction.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
addAction(int, ClientProtos.MultiAction.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
addActionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
addActionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
addAll(ArrayList<ByteRange>) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
building
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
 
addAllAction(Iterable<? extends AccessControlProtos.Permission.Action>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
addAllAction(Iterable<? extends ClientProtos.MultiAction>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
addAllAttribute(Iterable<? extends HBaseProtos.NameBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addAllAttribute(Iterable<? extends HBaseProtos.NameBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addAllAttribute(Iterable<? extends HBaseProtos.NameBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addAllAttributes(Iterable<? extends HBaseProtos.BytesBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addAllAttributes(Iterable<? extends HBaseProtos.BytesBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addAllAttrs(Iterable<? extends ColumnSchemaMessage.ColumnSchema.Attribute>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
addAllAttrs(Iterable<? extends TableSchemaMessage.TableSchema.Attribute>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addAllBackupMasters(Iterable<? extends HBaseProtos.ServerName>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addAllCell(Iterable<? extends HBaseProtos.Cell>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
addAllColumn(Iterable<? extends ClientProtos.Column>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addAllColumn(Iterable<? extends ClientProtos.Column>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addAllColumnFamilies(Iterable<? extends HBaseProtos.ColumnFamilySchema>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addAllColumns(Iterable<? extends ByteString>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
addAllColumns(Iterable<? extends ColumnSchemaMessage.ColumnSchema>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addAllColumnValue(Iterable<? extends ClientProtos.MutationProto.ColumnValue>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addAllConfiguration(Iterable<? extends HBaseProtos.NameStringPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addAllConfiguration(Iterable<? extends HBaseProtos.NameStringPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addAllCoprocessors(Iterable<? extends HBaseProtos.Coprocessor>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addAllDeadNodes(Iterable<String>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
addAllDeadServers(Iterable<? extends HBaseProtos.ServerName>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addAllEntry(Iterable<? extends AdminProtos.WALEntry>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
addAllExists(Iterable<? extends Boolean>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
addAllFamily(Iterable<? extends ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
addAllFamilyPath(Iterable<? extends ClientProtos.BulkLoadHFileRequest.FamilyPath>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
addAllFamilyPath(Iterable<? extends ClientProtos.BulkLoadHFileRequest.FamilyPath>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
addAllFamilyScope(Iterable<? extends AdminProtos.WALEntry.WALEdit.FamilyScope>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
addAllFilters(Iterable<? extends HBaseProtos.Filter>) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
addAllFirstPart(Iterable<? extends ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
addAllFuzzyKeysData(Iterable<? extends HBaseProtos.BytesBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
addAllGet(Iterable<? extends ClientProtos.Get>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
addAllKeyValueBytes(Iterable<? extends ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
addAllLiveNodes(Iterable<? extends StorageClusterStatusMessage.StorageClusterStatus.Node>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
addAllLiveServers(Iterable<? extends ClusterStatusProtos.LiveServerInfo>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addAllMapEntries(Iterable<? extends HBaseProtos.NameStringPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
addAllMapEntry(Iterable<? extends HBaseProtos.BytesBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
addAllMasterCoprocessors(Iterable<? extends HBaseProtos.Coprocessor>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addAllMetrics(Iterable<? extends HBaseProtos.NameInt64Pair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
addAllMutationRequest(Iterable<? extends ClientProtos.MutationProto>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
addAllName(Iterable<String>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
addAllOpenInfo(Iterable<? extends AdminProtos.OpenRegionRequest.RegionOpenInfo>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
addAllOpeningState(Iterable<? extends AdminProtos.OpenRegionResponse.RegionOpeningState>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
addAllPermission(Iterable<? extends AccessControlProtos.Permission>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
addAllPermission(Iterable<? extends AccessControlProtos.UserPermission>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
addAllPermissions(Iterable<? extends AccessControlProtos.UserTablePermissions.UserPermissions>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
addAllPermissions(Iterable<? extends AccessControlProtos.Permission>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
addAllQualifier(Iterable<? extends ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
addAllQualifiers(Iterable<? extends ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
addAllQualifierValue(Iterable<? extends ClientProtos.MutationProto.ColumnValue.QualifierValue>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
addAllRegionInfo(Iterable<? extends HBaseProtos.RegionInfo>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
addAllRegionLoads(Iterable<? extends HBaseProtos.RegionLoad>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addAllRegions(Iterable<? extends StorageClusterStatusMessage.StorageClusterStatus.Region>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
addAllRegions(Iterable<? extends TableInfoMessage.TableInfo.Region>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
addAllRegionsInTransition(Iterable<? extends ClusterStatusProtos.RegionInTransition>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addAllRegionToFlush(Iterable<? extends ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
addAllResult(Iterable<? extends ClientProtos.Result>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
addAllResult(Iterable<? extends ClientProtos.ActionResult>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
addAllResult(Iterable<? extends ClientProtos.Result>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
addAllRows(Iterable<? extends CellSetMessage.CellSet.Row>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
addAllSnapshots(Iterable<? extends HBaseProtos.SnapshotDescription>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
addAllSortedPrefixes(Iterable<? extends ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
addAllSplitKeys(Iterable<? extends ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
addAllStoreFile(Iterable<String>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
addAllTableNames(Iterable<String>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
addAllTableSchema(Iterable<? extends HBaseProtos.TableSchema>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
addAllTimestamps(Iterable<? extends Long>) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
addAllTrace(Iterable<? extends ErrorHandlingProtos.StackTraceElementMessage>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
addAllValues(Iterable<? extends CellMessage.Cell>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
addAndGetGlobalMemstoreSize(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Increase the size of mem store in this region and the size of global mem store
addAndGetGlobalMemstoreSize(long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
 
addAndGetRegionReplayEditsSize(byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
Add memStoreSize to replayEditsPerRegion.
addAttribute(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addAttribute(int, HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addAttribute(HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addAttribute(int, HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addAttribute(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addAttribute(int, HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addAttribute(HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addAttribute(int, HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addAttribute(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addAttribute(int, HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addAttribute(HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addAttribute(int, HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addAttribute(String, Object) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
Add an attribute to the column family schema
addAttribute(String, Object) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
Add an attribute to the table descriptor
addAttributeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addAttributeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addAttributeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addAttributeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addAttributeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addAttributeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addAttributes(HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addAttributes(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addAttributes(HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addAttributes(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addAttributes(HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addAttributes(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addAttributes(HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addAttributes(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addAttributesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addAttributesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addAttributesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addAttributesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addAttrs(ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
addAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
addAttrs(ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
addAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
addAttrs(TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addAttrs(int, TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addAttrs(TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addAttrs(int, TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addAttrsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
addAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
addAttrsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addBackupMasters(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addBackupMasters(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addBackupMasters(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addBackupMasters(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addBackupMastersBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addBackupMastersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addCall(HBaseClient.Call) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
Add a call to this connection's call queue and notify a listener; synchronized.
addCell(HBaseProtos.Cell) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
addCell(int, HBaseProtos.Cell) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
addCell(HBaseProtos.Cell.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
addCell(int, HBaseProtos.Cell.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
addCell(CellModel) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
Adds a cell to the list of cells for this row
addCellBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
addCellBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
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
 
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Get
Get the column from the specific family with the specified qualifier.
addColumn(String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Add a column to an existing table.
addColumn(byte[], 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[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get the column from the specified family with the specified qualifier.
addColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
 
addColumn(RpcController, MasterAdminProtos.AddColumnRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
addColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
Add column to a table
addColumn(byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Add a new column to an existing table
addColumn(ClientProtos.Column) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addColumn(int, ClientProtos.Column) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addColumn(ClientProtos.Column.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addColumn(int, ClientProtos.Column.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addColumn(ClientProtos.Column) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addColumn(int, ClientProtos.Column) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addColumn(ClientProtos.Column.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addColumn(int, ClientProtos.Column.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addColumn(RpcController, MasterAdminProtos.AddColumnRequest, RpcCallback<MasterAdminProtos.AddColumnResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
addColumn(RpcController, MasterAdminProtos.AddColumnRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
addColumn(RpcController, MasterAdminProtos.AddColumnRequest, RpcCallback<MasterAdminProtos.AddColumnResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
addColumn(RpcController, MasterAdminProtos.AddColumnRequest, RpcCallback<MasterAdminProtos.AddColumnResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
addColumn(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
Add a column to the column set
addColumn(byte[]) - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
addColumnBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addColumnBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
addColumnBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addColumnBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
addColumnFamilies(HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addColumnFamilies(int, HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addColumnFamilies(HBaseProtos.ColumnFamilySchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addColumnFamilies(int, HBaseProtos.ColumnFamilySchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addColumnFamiliesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addColumnFamiliesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addColumnFamily(ColumnSchemaModel) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
Add a column family to the table descriptor
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
 
addColumns(ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addColumns(int, ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addColumns(ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addColumns(int, ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addColumnsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addColumnsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
addColumnValue(ClientProtos.MutationProto.ColumnValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addColumnValue(int, ClientProtos.MutationProto.ColumnValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addColumnValue(ClientProtos.MutationProto.ColumnValue.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addColumnValue(int, ClientProtos.MutationProto.ColumnValue.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addColumnValueBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addColumnValueBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
addCompactionResults(Collection<StoreFile>, Collection<StoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Adds compaction results into the structure.
addConfiguration(HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addConfiguration(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addConfiguration(HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addConfiguration(HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addConfiguration(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addConfiguration(HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addConfigurationBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
addConfigurationBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
addCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Add a table coprocessor to this table.
addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Add a table coprocessor to this table.
addCoprocessors(HBaseProtos.Coprocessor) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addCoprocessors(int, HBaseProtos.Coprocessor) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addCoprocessors(HBaseProtos.Coprocessor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addCoprocessors(int, HBaseProtos.Coprocessor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addCoprocessorsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addCoprocessorsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addDaughter(CatalogTracker, HRegionInfo, ServerName, long) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Adds a daughter region entry to meta.
addDaughtersToPut(Put, HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
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
 
addDeadServers(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addDeadServers(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addDeadServers(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addDeadServers(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addDeadServersBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addDeadServersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
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(KeyValue) - Method in class org.apache.hadoop.hbase.client.Delete
Advanced use only.
addDependencyJars(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated.  
addDependencyJars(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Add the HBase dependency jars as well as jars for any of the configured job classes to the job configuration, so that JobClient will ship them to the cluster and add them to the DistributedCache.
addDependencyJars(Configuration, Class...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Add the jars containing the given classes to the job's configuration such that JobClient will ship them to the cluster and add them to the DistributedCache.
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(AdminProtos.WALEntry) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
addEntry(int, AdminProtos.WALEntry) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
addEntry(AdminProtos.WALEntry.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
addEntry(int, AdminProtos.WALEntry.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
addEntry(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.LRUDictionary
 
addEntryBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
addEntryBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
addExists(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
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.Get
Get all columns from the specified family.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get all columns from the specified family.
addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
Does NOT add a column family.
addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Adds a column family.
addFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
addFamilyPath(ClientProtos.BulkLoadHFileRequest.FamilyPath) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
addFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
addFamilyPath(ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
addFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
addFamilyPath(ClientProtos.BulkLoadHFileRequest.FamilyPath) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
addFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
addFamilyPath(ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
addFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
addFamilyPathBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
addFamilyPathBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
addFamilyPathBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
addFamilyPathBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
addFamilyScope(AdminProtos.WALEntry.WALEdit.FamilyScope) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
addFamilyScope(int, AdminProtos.WALEntry.WALEdit.FamilyScope) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
addFamilyScope(AdminProtos.WALEntry.WALEdit.FamilyScope.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
addFamilyScope(int, AdminProtos.WALEntry.WALEdit.FamilyScope.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
addFamilyScopeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
addFamilyScopeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
addFileInfoToException(IOException) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
addFilter(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
Add a filter.
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
addFilters(HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
addFilters(int, HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
addFilters(HBaseProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
addFilters(int, HBaseProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
addFiltersBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
addFiltersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
addFirstPart(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
addFuzzyKeysData(HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
addFuzzyKeysData(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
addFuzzyKeysData(HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
addFuzzyKeysData(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
addFuzzyKeysDataBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
addFuzzyKeysDataBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
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
 
addGet(ClientProtos.Get) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
addGet(int, ClientProtos.Get) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
addGet(ClientProtos.Get.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
addGet(int, ClientProtos.Get.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
addGetBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
addGetBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
addHbaseResources(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
 
addHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
addHostsAndBlockWeight(String[], long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
add some weight to a list of hosts, update the value of unique block weight
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
 
addJitter(long, float) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Adds / subs a 10% jitter to a pause time.
addKey(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
addKeyToZK(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
addKeyValueBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
addLease(Leases.Lease) - Method in class org.apache.hadoop.hbase.regionserver.Leases
Inserts lease.
addListener(ForeignExceptionListener) - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
Listen for failures to a given process.
addLiveNode(String, long, int, int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
Add a live node to the cluster representation.
addLiveNodes(StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
addLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
addLiveNodes(StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
addLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
addLiveNodesBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
addLiveNodesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
addLiveServers(ClusterStatusProtos.LiveServerInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addLiveServers(int, ClusterStatusProtos.LiveServerInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addLiveServers(ClusterStatusProtos.LiveServerInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addLiveServers(int, ClusterStatusProtos.LiveServerInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addLiveServersBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addLiveServersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addLocationsOrderInterceptor(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
 
addLogToList(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Add a new log to the list of hlogs in zookeeper
addMapEntries(HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
addMapEntries(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
addMapEntries(HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
addMapEntries(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
addMapEntriesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
addMapEntriesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
addMapEntry(HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
addMapEntry(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
addMapEntry(HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
addMapEntry(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
addMapEntryBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
addMapEntryBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
addMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addMaster(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addMaster(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addMasterCoprocessors(HBaseProtos.Coprocessor) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addMasterCoprocessors(int, HBaseProtos.Coprocessor) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addMasterCoprocessors(HBaseProtos.Coprocessor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addMasterCoprocessors(int, HBaseProtos.Coprocessor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addMasterCoprocessorsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addMasterCoprocessorsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addMetrics(HBaseProtos.NameInt64Pair) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
addMetrics(int, HBaseProtos.NameInt64Pair) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
addMetrics(HBaseProtos.NameInt64Pair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
addMetrics(int, HBaseProtos.NameInt64Pair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
addMetricsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
addMetricsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
addMutationRequest(ClientProtos.MutationProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
addMutationRequest(int, ClientProtos.MutationProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
addMutationRequest(ClientProtos.MutationProto.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
addMutationRequest(int, ClientProtos.MutationProto.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
addMutationRequestBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
addMutationRequestBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
addName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
addNode(TokenizerNode, int, int, ByteRange, int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
addOpenInfo(AdminProtos.OpenRegionRequest.RegionOpenInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
addOpenInfo(int, AdminProtos.OpenRegionRequest.RegionOpenInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
addOpenInfo(AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
addOpenInfo(int, AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
addOpenInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
addOpenInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
addOpeningState(AdminProtos.OpenRegionResponse.RegionOpeningState) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
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
 
addOptWithArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
addPeer(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Add a new peer cluster to replicate to.
addPeer(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Add a new peer to this cluster
addPermission(AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
addPermission(int, AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
addPermission(AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
addPermission(int, AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
addPermission(AccessControlProtos.UserPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
addPermission(int, AccessControlProtos.UserPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
addPermission(AccessControlProtos.UserPermission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
addPermission(int, AccessControlProtos.UserPermission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
addPermissionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
addPermissionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
addPermissionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
addPermissionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
addPermissions(AccessControlProtos.UserTablePermissions.UserPermissions) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
addPermissions(int, AccessControlProtos.UserTablePermissions.UserPermissions) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
addPermissions(AccessControlProtos.UserTablePermissions.UserPermissions.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
addPermissions(int, AccessControlProtos.UserTablePermissions.UserPermissions.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
addPermissions(AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
addPermissions(int, AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
addPermissions(AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
addPermissions(int, AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
addPermissionsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
addPermissionsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
addPermissionsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
addPermissionsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
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.
addQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
addQualifiers(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
addQualifierValue(ClientProtos.MutationProto.ColumnValue.QualifierValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
addQualifierValue(int, ClientProtos.MutationProto.ColumnValue.QualifierValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
addQualifierValue(ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
addQualifierValue(int, ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
addQualifierValueBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
addQualifierValueBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
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
addRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
addRegionInfo(int, HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
addRegionInfo(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
addRegionInfo(int, HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
addRegionInfo(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
 
addRegionInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
addRegionInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
addRegionLoads(HBaseProtos.RegionLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addRegionLoads(int, HBaseProtos.RegionLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addRegionLoads(HBaseProtos.RegionLoad.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addRegionLoads(int, HBaseProtos.RegionLoad.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addRegionLoadsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addRegionLoadsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
addRegions(StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
addRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
addRegions(StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
addRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
addRegions(TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
addRegions(int, TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
addRegions(TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
addRegions(int, TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
addRegionsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
addRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
addRegionsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
addRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
addRegionServer() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addRegionServer(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addRegionServer(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addRegionsInTransition(ClusterStatusProtos.RegionInTransition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addRegionsInTransition(int, ClusterStatusProtos.RegionInTransition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addRegionsInTransition(ClusterStatusProtos.RegionInTransition.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addRegionsInTransition(int, ClusterStatusProtos.RegionInTransition.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addRegionsInTransitionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addRegionsInTransitionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
addRegionsToMeta(CatalogTracker, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Adds a META row for each of the specified new regions.
addRegionToFlush(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
addRegionToMeta(CatalogTracker, HRegionInfo) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Adds a META row for the specified new region.
addRegionToMeta(HTable, HRegionInfo) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Adds a META row for the specified new region to the given catalog table.
addRegionToMeta(HTable, HRegionInfo, HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Adds a (single) 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.
addRequiredOptWithArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
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
 
addResult(ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
addResult(int, ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
addResult(ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
addResult(int, ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
addResult(ClientProtos.ActionResult) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
addResult(int, ClientProtos.ActionResult) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
addResult(ClientProtos.ActionResult.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
addResult(int, ClientProtos.ActionResult.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
addResult(ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
addResult(int, ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
addResult(ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
addResult(int, ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
addResultBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
addResultBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
addResultBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
addResultBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
addResultBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
addResultBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
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
 
addRows(int, CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
addRows(CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
addRows(int, CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
addRowsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
addRowsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
addScanner(RegionScanner) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
addScanner(ResultScanner) - 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.
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
 
addShutdownHook(Thread, int) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
 
addSlabByConf(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
A way of allocating the desired amount of Slabs of each particular size.
addSnapshots(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
addSnapshots(int, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
addSnapshots(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
addSnapshots(int, HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
addSnapshotsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
addSnapshotsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
addSorted(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
addSorted(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
building
addSortedPrefixes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
addSource(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Add a new normal source to this region server
addSplit(long, long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
Record a single instance of a split
addSplitKeys(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
addStoreFile(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
addStringMap(Map<String, String>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
Add String map to config list.
addTable(String) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
Add the named table to be those being archived.
addTableNames(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
addTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
addTableSchema(int, HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
addTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
addTableSchema(int, HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
addTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
addTableSchemaBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
addTimestamps(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
addToColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
addToColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
addToColumns(TColumnIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
addToColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
addToColumnValues(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
addToColumnValues(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
addToDeletes(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
addToGets(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
addToMovedRegions(String, ServerName, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
addToOnlineRegions(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
addToPuts(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
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(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
 
addToSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
 
addToSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
addTrace(ErrorHandlingProtos.StackTraceElementMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
addTrace(int, ErrorHandlingProtos.StackTraceElementMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
addTrace(ErrorHandlingProtos.StackTraceElementMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
addTrace(int, ErrorHandlingProtos.StackTraceElementMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
addTraceBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
addTraceBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
addValues(CellMessage.Cell) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
addValues(int, CellMessage.Cell) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
addValues(CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
addValues(int, CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
addValuesBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
addValuesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
addWeight(long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
add weight
addWritableMap(Map<ImmutableBytesWritable, ImmutableBytesWritable>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
Add ImmutableBytesWritable map to config list.
admin - Variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
ADMIN_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
 
AdminProtocol - Interface in org.apache.hadoop.hbase.client
Protocol that a HBase client uses to communicate with a region server.
AdminProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.AdminService - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.AdminService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
AdminProtos.AdminService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.AdminService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.AdminService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.CloseRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.CloseRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.CloseRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.CloseRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.CloseRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.CloseRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.CompactRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.CompactRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.CompactRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.CompactRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.CompactRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.CompactRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.FlushRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.FlushRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.FlushRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.FlushRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.FlushRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.FlushRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetOnlineRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetOnlineRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetOnlineRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetOnlineRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetOnlineRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetOnlineRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetRegionInfoRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetRegionInfoRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetRegionInfoRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetRegionInfoResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetRegionInfoResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetRegionInfoResponse.CompactionState - Enum in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetRegionInfoResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetServerInfoRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetServerInfoRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetServerInfoRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetServerInfoResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetServerInfoResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetServerInfoResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetStoreFileRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetStoreFileRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetStoreFileRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetStoreFileResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetStoreFileResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.GetStoreFileResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.MergeRegionsRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.MergeRegionsRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.MergeRegionsRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.MergeRegionsResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.MergeRegionsResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.MergeRegionsResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.OpenRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.OpenRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.OpenRegionRequest.RegionOpenInfo - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.OpenRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.OpenRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.OpenRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.OpenRegionResponse.RegionOpeningState - Enum in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.OpenRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.ReplicateWALEntryRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.ReplicateWALEntryRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.ReplicateWALEntryRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.ReplicateWALEntryResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.ReplicateWALEntryResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.ReplicateWALEntryResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.RollWALWriterRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.RollWALWriterRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.RollWALWriterRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.RollWALWriterResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.RollWALWriterResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.RollWALWriterResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.ServerInfo - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.ServerInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.ServerInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.SplitRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.SplitRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.SplitRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.SplitRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.SplitRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.SplitRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.StopServerRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.StopServerRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.StopServerRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.StopServerResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.StopServerResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.StopServerResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.UUID - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.UUID.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.UUIDOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.WALEntry - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.WALEntry.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.WALEntry.WALEdit - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.WALEntry.WALEdit.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.WALEntry.WALEdit.FamilyScope - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.WALEntry.WALEdit.FamilyScope.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.WALEntry.WALEdit.FamilyScopeOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.WALEntry.WALEdit.ScopeType - Enum in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.WALEntry.WALEditOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.WALEntry.WALKey - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.WALEntry.WALKey.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.WALEntry.WALKeyOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AdminProtos.WALEntryOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
advance() - Method in interface org.apache.hadoop.hbase.CellScanner
Advance the scanner 1 cell.
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
 
affixShutdownHook(Thread, int) - Static method in class org.apache.hadoop.hbase.util.ShutdownHookManager
 
afterCall() - Method in class org.apache.hadoop.hbase.client.ServerCallable
 
afterExecute() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
Called after compaction is executed by CompactSplitThread; for use by coproc subclasses.
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
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
 
AggregateProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
AggregateProtos.AggregateArgument - Class in org.apache.hadoop.hbase.protobuf.generated
 
AggregateProtos.AggregateArgument.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AggregateProtos.AggregateArgumentOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AggregateProtos.AggregateResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AggregateProtos.AggregateResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AggregateProtos.AggregateResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AggregateProtos.AggregateService - Class in org.apache.hadoop.hbase.protobuf.generated
 
AggregateProtos.AggregateService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
AggregateProtos.AggregateService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AggregateProtos.AggregateService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AggregateProtos.AggregateService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
 
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'.
allActions() - Method in class org.apache.hadoop.hbase.client.MultiAction
 
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.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, byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
 
allow(String, String, User, Permission.Action, byte[], Map<byte[], ? extends Collection<?>>) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
 
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, byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Lists all of the table regions currently in META.
allTypes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
ALREADY_OPENED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
 
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_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
 
Append - Class in org.apache.hadoop.hbase.client
Performs Append operations on a single row.
Append(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Append
Create a Append operation for the specified row.
Append(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Append
Create a Append operation for the specified row.
append(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 interface org.apache.hadoop.hbase.client.HTableInterface
Appends values to one or more columns within a single row.
append(KeyValue) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
 
append(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
 
append(KeyValue) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Add key/value to file.
append(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Add key/value to file.
append(KeyValue) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.Compactor.CellSink
 
append(Append, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Perform one or more append operations on a row.
append(HRegion, ClientProtos.MutationProto, CellScanner) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Execute an append mutation.
append(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
 
append(HRegionInfo, HLogKey, WALEdit, HTableDescriptor, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
Append an entry to the log.
append(HRegionInfo, byte[], WALEdit, long, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
Only used in tests.
append(HRegionInfo, byte[], WALEdit, UUID, long, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
Append a set of edits to the log.
append(HLog.Entry) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Writer
 
append(HLog.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
 
append(Append) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
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.wal.MetricsWALSource
 
APPEND_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
APPEND_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
 
appendCurrentTokenToRowBuffer() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
helper methods
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
 
appendKeyToByteArrayWithoutValue(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
appendKeyValue(StringBuilder, String, Object) - Static method in class org.apache.hadoop.hbase.util.Strings
Append to a StringBuilder a key/value.
appendKeyValue(StringBuilder, String, Object, String, String) - Static method in class org.apache.hadoop.hbase.util.Strings
Append to a StringBuilder a key/value.
appendMetaBlock(String, Writable) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
 
appendMetaBlock(String, Writable) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Add a meta block to the end of the file.
appendMetadata(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
Writes meta data.
appendNodes(List<TokenizerNode>, boolean, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
appendNodesToExternalList(List<TokenizerNode>, boolean, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
moving nodes around
appendNoSync(HRegionInfo, byte[], WALEdit, UUID, long, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
Append a set of edits to the log.
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
 
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
applyBatch(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
Convience method to change metrics when a batch of operations are applied.
applyClusterKeyToConf(Configuration, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Apply the settings in the given key to the given configuration, this is used to communicate with distant clusters
archiveFamily(FileSystem, Configuration, HRegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Remove from the specified region the store files of the specified column family, either by archiving them or outright deletion
archiveRegion(Configuration, FileSystem, HRegionInfo) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Cleans up all the files for a HRegion by archiving the HFiles to the archive directory
archiveRegion(FileSystem, Path, Path, Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Remove an entire region from the table directory via archiving the region's hfiles.
archiveStoreFile(Configuration, FileSystem, HRegionInfo, Path, byte[], Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Archive the store file
archiveStoreFiles(Configuration, FileSystem, HRegionInfo, Path, byte[], Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Remove the store files, either by archiving them or outright deletion
areAdjacent(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Check whether two regions are adjacent
areAllSameType() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
get/set
areBuffersBigEnough() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
Call when first accessing a block.
areDeadServersInProgress() - Method in class org.apache.hadoop.hbase.master.DeadServer
Checks if there are currently any dead servers being processed by the master.
areDeadServersInProgress() - Method in class org.apache.hadoop.hbase.master.ServerManager
Checks if any dead servers are currently in progress.
areKeyLengthsEqual(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
lengths
arePartsEqual(ByteBuffer, int, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Check whether two parts in the same buffer are equal.
areRowLengthsEqual(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
 
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
 
ArrayUtils() - Constructor for class org.apache.hadoop.hbase.util.ArrayUtils
 
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 class org.apache.hadoop.hbase.client.HBaseAdmin
 
assign(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Assigns the specified region.
assign(HRegionInfo, boolean, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Use care with forceNewPlan.
assign(Map<HRegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Assigns specified regions retaining assignments, if any.
assign(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Assigns specified regions round robin, if any.
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) - Constructor for class org.apache.hadoop.hbase.master.AssignCallable
 
AssignmentManager - Class in org.apache.hadoop.hbase.master
Manages and performs region assignment.
AssignmentManager(Server, ServerManager, CatalogTracker, LoadBalancer, ExecutorService, MetricsMaster, TableLockManager) - Constructor for class org.apache.hadoop.hbase.master.AssignmentManager
Constructs a new assignment manager.
AssignmentManager.TimeoutMonitor - Class in org.apache.hadoop.hbase.master
Monitor to check for time outs on region transition operations
AssignmentManager.TimeoutMonitor(int, Stoppable, ServerManager, int) - Constructor for class org.apache.hadoop.hbase.master.AssignmentManager.TimeoutMonitor
Creates a periodic monitor to check for time outs on region transition operations.
AssignmentManager.TimerUpdater - Class in org.apache.hadoop.hbase.master
Update timers for all regions in transition going against the server in the serversInUpdatingTimer.
AssignmentManager.TimerUpdater(int, Stoppable) - Constructor for class org.apache.hadoop.hbase.master.AssignmentManager.TimerUpdater
 
AssignmentManagerStatusTmpl - Class in org.apache.hadoop.hbase.tmpl.master
 
AssignmentManagerStatusTmpl(TemplateManager) - 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
 
assignmentZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
assignMeta() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Assigns the META region.
assignRegion(RpcController, MasterAdminProtos.AssignRegionRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
assignRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.HMaster
 
assignRegion(RpcController, MasterAdminProtos.AssignRegionRequest, RpcCallback<MasterAdminProtos.AssignRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
assignRegion(RpcController, MasterAdminProtos.AssignRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
assignRegion(RpcController, MasterAdminProtos.AssignRegionRequest, RpcCallback<MasterAdminProtos.AssignRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
assignRegion(RpcController, MasterAdminProtos.AssignRegionRequest, RpcCallback<MasterAdminProtos.AssignRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
assignRegions(AssignmentManager, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
Trigger immediate assignment of the regions in round-robin fashion
ASSIGNSEQNUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
ASSIGNSEQNUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
ASSOCIATEDCELLCOUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
ASSOCIATEDCELLCOUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
assumeUncompressed() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
An additional sanity-check in case no compression is being used.
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.
ATOMIC_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for AtomicBoolean
ATOMIC_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
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) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Deprecated. 
atomicIncrement(ByteBuffer, ByteBuffer, byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
attemptingUser - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
 
ATTRIBUTE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
ATTRIBUTE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
ATTRIBUTE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
Attributes - Interface in org.apache.hadoop.hbase.client
 
ATTRIBUTES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
ATTRIBUTES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
ATTRS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
ATTRS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
AUTH_TOKEN_TYPE - Static variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
AUTHENTICATION_FAILURES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHENTICATION_FAILURES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHENTICATION_SUCCESSES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHENTICATION_SUCCESSES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authenticationFailure() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authenticationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
AuthenticationKey - Class in org.apache.hadoop.hbase.security.token
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
 
AuthenticationProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.AuthenticationKey - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.AuthenticationKey.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.AuthenticationKeyOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.AuthenticationService - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.AuthenticationService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
 
AuthenticationProtos.AuthenticationService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.AuthenticationService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.AuthenticationService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.Token - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.Token.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.TokenIdentifier - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.TokenIdentifier.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.TokenIdentifier.Kind - Enum in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.TokenIdentifierOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.TokenOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.TokenRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.TokenRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.TokenRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.TokenResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.TokenResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.TokenResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.WhoAmIRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.WhoAmIRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.WhoAmIRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.WhoAmIResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.WhoAmIResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
AuthenticationProtos.WhoAmIResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
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
 
authManager - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
AuthMethod - Enum in org.apache.hadoop.hbase.security
Authentication method
AUTHMETHOD_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
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
 
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.HBaseServer
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, byte[], KeyValue, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
authorize(User, byte[], byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
authorize(User, byte[], 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 authorization for a given action for a group, based on the stored permissions.
authorizeGroup(String, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Checks authorization to a given table and column family for a group, based on the stored permissions.
authorizeUser(String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Checks global authorization for a specific action for a user, based on the stored user permissions.
authorizeUser(String, byte[], 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(String, byte[], 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, byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
 
AuthResult(boolean, String, String, User, Permission.Action, byte[], Map<byte[], ? extends Collection<?>>) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
 
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
 
AVERAGELOAD_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
avg(byte[], ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
This is the client side interface/handle for calling the average method for a given cf-cq combination.
avgKeyLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Average key length read from file info
avgValueLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Average value length read from file info

B

BACK_REFERENCES_DIRECTORY_PREFIX - Static variable in class org.apache.hadoop.hbase.io.FileLink
Define the Back-reference directory name prefix: .links-/
BACKSLASH - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for Backslash
backupMasterAddressesZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
BackupMasterListTmpl - Class in org.apache.hadoop.hbase.tmpl.master
 
BackupMasterListTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.master.BackupMasterListTmpl
 
BackupMasterListTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.master.BackupMasterListTmpl
 
BackupMasterListTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.master
 
BackupMasterListTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.master.BackupMasterListTmpl.ImplData
 
BackupMasterListTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.master
 
BackupMasterListTmplImpl - Class in org.apache.hadoop.hbase.tmpl.master
 
BackupMasterListTmplImpl(TemplateManager, BackupMasterListTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.master.BackupMasterListTmplImpl
 
BACKUPMASTERS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
balance(RegionPlan) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
balance() - Method in class org.apache.hadoop.hbase.master.HMaster
 
balance(RpcController, MasterAdminProtos.BalanceRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
balance(RpcController, MasterAdminProtos.BalanceRequest, RpcCallback<MasterAdminProtos.BalanceResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
balance(RpcController, MasterAdminProtos.BalanceRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
balance(RpcController, MasterAdminProtos.BalanceRequest, RpcCallback<MasterAdminProtos.BalanceResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
balance(RpcController, MasterAdminProtos.BalanceRequest, RpcCallback<MasterAdminProtos.BalanceResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
balanceCluster(Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.DefaultLoadBalancer
Generate a global load balancing plan according to the specified map of server information to the most loaded regions of each server.
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(Map<ServerName, List<HRegionInfo>>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Perform the major balance operation
balancer() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Invoke the balancer.
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
 
BALANCERON_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
BALANCERON_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
BALANCERRAN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
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) - Method in class org.apache.hadoop.hbase.procedure.Procedure
Call back triggered by a individual member upon successful local in-barrier execution and release
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) - Constructor for class org.apache.hadoop.hbase.util.Base64.Base64InputStream
Constructs a Base64.Base64InputStream in DECODE mode.
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) - Constructor for class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Constructs a Base64.Base64OutputStream in ENCODE mode.
Base64.Base64OutputStream(OutputStream, int) - Constructor for class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Constructs a Base64.Base64OutputStream in either ENCODE or DECODE mode.
BaseConfigurable - Class in org.apache.hadoop.hbase
HBase version of Hadoop's Configured class that doesn't initialize the configuration via BaseConfigurable.setConf(Configuration) in the constructor, but only sets the configuration through the BaseConfigurable.setConf(Configuration) method
BaseConfigurable() - Constructor for class org.apache.hadoop.hbase.BaseConfigurable
 
BaseConstraint - Class in org.apache.hadoop.hbase.constraint
Base class to use when actually implementing a Constraint.
BaseConstraint() - Constructor for class org.apache.hadoop.hbase.constraint.BaseConstraint
 
BaseDecoder - Class in org.apache.hadoop.hbase.codec
 
BaseDecoder(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.BaseDecoder
 
BaseEncoder - Class in org.apache.hadoop.hbase.codec
 
BaseEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.BaseEncoder
 
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
 
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
 
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
 
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 HRegion.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
 
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[]) - Method in class org.apache.hadoop.hbase.client.HTable
 
batch(List<? extends Row>) - Method in class org.apache.hadoop.hbase.client.HTable
 
batch(List<? extends Row>, Object[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends and RowMutations.
batch(List<? extends Row>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Same as HTableInterface.batch(List, Object[]), but returns an array of results instead of using a results parameter reference.
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
 
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
 
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Same as HTableInterface.batch(List, Object[]), but with a callback.
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Same as HTableInterface.batch(List), but with a callback.
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
 
batchMutate(Pair<Mutation, Integer>[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Perform a batch of mutations.
BATCHSIZE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
beforeCall() - Method in class org.apache.hadoop.hbase.client.ServerCallable
 
beforeExecute() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
Called before compaction is executed by CompactSplitThread; for use by coproc subclasses.
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
beforeWriteToDisk(ByteBuffer, boolean, HFileBlockEncodingContext, BlockType) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Should be called before an encoded or unencoded data block is written to disk.
beforeWriteToDisk(ByteBuffer, boolean, HFileBlockEncodingContext, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
Precondition: a non-encoded buffer.
beforeWriteToDisk(ByteBuffer, boolean, HFileBlockEncodingContext, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
beginMemstoreInsert() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
Generate and return a MultiVersionConsistencyControl.WriteEntry with a new write number.
beginOp() - Method in class org.apache.hadoop.hbase.util.DrainBarrier
Tries to start an operation.
beginPersistentOutput() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
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
 
BIGDECIMALMSG_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
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(KeyValue[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
 
binarySearch(KeyValue[], 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<byte[]>) - 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.HBaseServer
A convenience method to bind to a given address and report better exceptions if the address is not a valid host.
bindAddress - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
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
 
BITWISEOP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
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_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_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_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_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_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_COUNT_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
blockBuffer - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
BlockCache - Interface in org.apache.hadoop.hbase.io.hfile
Block cache interface.
BlockCacheColumnFamilySummary - Class in org.apache.hadoop.hbase.io.hfile
BlockCacheColumnFamilySummary represents a summary of the blockCache usage at Table/ColumnFamily granularity.
BlockCacheColumnFamilySummary() - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
Default constructor for Writable
BlockCacheColumnFamilySummary(String, String) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
 
BlockCacheKey - Class in org.apache.hadoop.hbase.io.hfile
Cache Key for use with implementations of BlockCache
BlockCacheKey(String, long, DataBlockEncoding, BlockType) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
BlockCacheKey(String, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
Construct a new BlockCacheKey
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
 
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
 
blockRange(long, long) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
Creates a block iterator over the given portion of the HFile.
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Size of storefile/hfile 'blocks'.
blockSize - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Number of uncompressed bytes we allow per block.
blockSize - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
blockSizeWritten() - 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.
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) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
Wait until the meta region is available.
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, byte[]) - 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.
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.
bloomFilterType - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
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
 
BOTTOM_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
 
BUCKET_CACHE_COMBINED_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
BUCKET_CACHE_COMBINED_PERCENTAGE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
BUCKET_CACHE_IOENGINE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration keys for Bucket cache
BUCKET_CACHE_PERSISTENT_PATH_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
BUCKET_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
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.
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 block, and use BucketCache.ramCache and BucketCache.backingMap in order to determine whether a given element hit.
BucketCache(String, long, int, int, String) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
BucketCache(String, long, int, int, String, int) - 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.
BucketCacheStats() - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
 
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
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
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
 
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.checkAndPut_args
 
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.checkAndPut_args
 
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.checkAndPut_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
 
bufferForStartRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
bufferForStopRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_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.get_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.increment_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
 
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.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.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.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.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.
buildAddColumnRequest(byte[], HColumnDescriptor) - 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() - 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
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
buildCatalogScanResponse(int) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the catalog scan request
buildCloseRegionRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a CloseRegionRequest for a given region name
buildCloseRegionRequest(byte[], int, ServerName, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
 
buildCloseRegionRequest(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
buildCreateTableRequest(HTableDescriptor, byte[][]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer CreateTableRequest
buildDeleteColumnRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer DeleteColumnRequest
buildDeleteTableRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer DeleteTableRequest
buildDisableTableRequest(byte[]) - 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(byte[]) - 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
 
builderNode - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
fields
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
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(long) - 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
buildGetRequest(byte[], Get, boolean) - 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(byte[]) - 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<String>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest
buildGrantRequest(String, byte[], byte[], byte[], AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to grant user permissions.
buildIsCatalogJanitorEnabledRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for querying the master whether the catalog janitor is enabled
buildIsMasterRunningRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsMasterRunningRequest
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(byte[], HColumnDescriptor) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ModifyColumnRequest
buildModifyTableRequest(byte[], HTableDescriptor) - 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
buildMultiGetRequest(byte[], List<Get>, boolean, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MultiGetRequest for client Gets All gets are going to be run against the same region.
buildMultiRequest(byte[], RowMutations) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MultiRequest for a row mutations
buildMultiRequest(byte[], List<Action<R>>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer multi request for a list of actions.
buildMultiRowSpec(byte[][], int) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildMutateRequest(byte[], byte[], byte[], byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a client increment
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[], Put) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a put
buildMutateRequest(byte[], Append) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for an append
buildMutateRequest(byte[], Increment) - 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
buildNoDataMultiRequest(byte[], RowMutations, List<CellScannable>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MultiRequest for row mutations that does not hold data.
buildNoDataMultiRequest(byte[], List<Action<R>>, List<CellScannable>) - 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).
buildOfflineRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer OfflineRegionRequest
buildOpenRegionRequest(List<Pair<HRegionInfo, Integer>>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer OpenRegionRequest to open a list of regions
buildOpenRegionRequest(HRegionInfo, int) - 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.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.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.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
 
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(HLog.Entry[]) - Static method in class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
Create a new ReplicateWALEntryRequest from a list of HLog entries
buildResultFromModel(CellSetModel) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildRevokeRequest(String, byte[], byte[], byte[], 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
 
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) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildScanRequest(long, int, boolean, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildSetBalancerRunningRequest(boolean, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer SetBalancerRunningRequest
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
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
 
buildUnassignRegionRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer UnassignRegionRequest
buildUserPermissionsResponse(List<UserPermission>) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Converts the permissions list into a protocol buffer UserPermissionsResponse
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
 
BulkDeleteProtos.BulkDeleteRequest.Builder - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteRequest.DeleteType - Enum in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteRequestOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteResponse - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteResponse.Builder - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteResponseOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteService - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
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_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
 
bulkLoadHFile(RpcController, ClientProtos.BulkLoadHFileRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface
 
bulkLoadHFile(RpcController, ClientProtos.BulkLoadHFileRequest, RpcCallback<ClientProtos.BulkLoadHFileResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
bulkLoadHFile(RpcController, ClientProtos.BulkLoadHFileRequest, RpcCallback<ClientProtos.BulkLoadHFileResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Interface
 
bulkLoadHFile(RpcController, ClientProtos.BulkLoadHFileRequest, RpcCallback<ClientProtos.BulkLoadHFileResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Stub
 
bulkLoadHFile(ClientProtocol, List<Pair<byte[], String>>, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to bulk load a list of HFiles using client protocol.
bulkLoadHFile(RpcController, ClientProtos.BulkLoadHFileRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Atomically bulk load several HFiles into an open region
bulkLoadHFile(String, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
bulkLoadHFile(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
This method should only be called from HRegion.
bulkLoadHFiles(List<Pair<byte[], String>>, Token<?>, String, byte[]) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
bulkLoadHFiles(List<Pair<byte[], String>>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
bulkLoadHFiles(List<Pair<byte[], String>>, boolean, HRegion.BulkLoadListener) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Attempts to atomically load a group of hfiles.
bulkLoadPhase(HTable, HConnection, 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
 
BULKTOKEN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
BULKTOKEN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
BULKTOKEN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
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.
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_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.
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.
ByteBufferIOEngine - Class in org.apache.hadoop.hbase.io.hfile.bucket
IO engine that stores data on the 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
 
ByteBufferUtils - Class in org.apache.hadoop.hbase.util
Utility functions for working with byte buffers, such as reading/writing variable-length long numbers.
ByteRange - Class in org.apache.hadoop.hbase.util
Lightweight, reusable class for specifying ranges of byte[]'s.
ByteRange() - Constructor for class org.apache.hadoop.hbase.util.ByteRange
construct
ByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.ByteRange
 
ByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.ByteRange
 
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
ByteRangeTool - Class in org.apache.hadoop.hbase.util
Utility methods ByteRange.
ByteRangeTool() - Constructor for class org.apache.hadoop.hbase.util.ByteRangeTool
 
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
 
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
 
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_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_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.
bytesPerChecksum - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
bytesPerChecksum - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
Bytes per Checksum
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
 

C

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
TODO: Implement this (jgray) Configuration key to cache data blocks in compressed format.
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_FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
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) - 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) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
Cache the block with the specified name and buffer.
cacheBlock(BlockCacheKey, Cacheable, 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) - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
 
cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
 
cacheBlock(BlockCacheKey, Cacheable, 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) - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
Cache the block with the specified key and buffer.
cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
We don't care about whether its in memory or not, so we just pass the call through.
cacheBlocks - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
cacheBlocks - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
CACHEBLOCKS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
CACHEBLOCKS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
cacheBlockWithWait(BlockCacheKey, Cacheable, 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.
CachedBlock - Class in org.apache.hadoop.hbase.io.hfile
Represents an entry in the LruBlockCache.
CachedBlock(BlockCacheKey, Cacheable, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
CachedBlock(BlockCacheKey, Cacheable, long, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
CachedBlockQueue - Class in org.apache.hadoop.hbase.io.hfile
A memory-bound queue that will grow until an element brings total size >= maxSize.
CachedBlockQueue(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.CachedBlockQueue
 
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
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() - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheStats
 
CacheStats(int) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheStats
 
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.
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
 
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() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
call(Method, Message, CellScanner, InetSocketAddress, Class<? extends IpcProtocol>, User, int) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
Make a call, passing param, to the IPC server running at address which is servicing the protocol protocol, with the ticket credentials, returning the value.
call(Class<? extends IpcProtocol>, Method, Message, CellScanner, long, MonitoredRPCHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
Called for each call.
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.snapshot.CopyRecoveredEditsTask
 
call() - Method in class org.apache.hadoop.hbase.snapshot.ReferenceRegionHFilesTask
 
call() - Method in class org.apache.hadoop.hbase.snapshot.ReferenceServerWALsTask
Create reference files (empty files with the same path and file name as original).
call() - Method in class org.apache.hadoop.hbase.snapshot.TableInfoCopyTask
 
call(Class<T>, T, String, Class[], Object[]) - Static method in class org.apache.hadoop.hbase.util.Methods
 
CALL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
CALL_QUEUE_LEN_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
callComplete() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Call
Indicate when the call is complete and the value or error are available.
CallerDisconnectedException - Exception in org.apache.hadoop.hbase.exceptions
Exception indicating that the remote host making this IPC lost its IPC connection.
CallerDisconnectedException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.CallerDisconnectedException
 
callExecService(Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
 
callExecService(Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.MasterCoprocessorRpcChannel
 
callExecService(Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
 
CALLID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
CALLID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
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.CoprocessorRpcChannel
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
 
callQueue - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
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.HBaseServer
 
calls - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
callTimeout - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
Canary - Class in org.apache.hadoop.hbase.tool
HBase Canary Tool, that that can be used to do "canary monitoring" of a running HBase cluster.
Canary() - Constructor for class org.apache.hadoop.hbase.tool.Canary
 
Canary(Canary.Sink) - Constructor for class org.apache.hadoop.hbase.tool.Canary
 
Canary.Sink - Interface in org.apache.hadoop.hbase.tool
 
Canary.StdOutSink - Class in org.apache.hadoop.hbase.tool
 
Canary.StdOutSink() - Constructor for class org.apache.hadoop.hbase.tool.Canary.StdOutSink
 
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.
CancelableProgressable - Interface in org.apache.hadoop.hbase.util
Similar interface as Progressable but returns a boolean to support canceling the operation.
cancelConnections(String, int, IOException) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
Interrupt the connections to the given ip:port 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
 
canQueue() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
canSplit() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
canSplit() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
castToCellType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
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(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
 
CatalogTracker - Class in org.apache.hadoop.hbase.catalog
Tracks the availability of the catalog tables .META..
CatalogTracker(Configuration) - Constructor for class org.apache.hadoop.hbase.catalog.CatalogTracker
Constructs a catalog tracker.
CatalogTracker(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.catalog.CatalogTracker
Constructs the catalog tracker.
CatalogTracker(ZooKeeperWatcher, Configuration, HConnection, Abortable) - Constructor for class org.apache.hadoop.hbase.catalog.CatalogTracker
 
catalogTracker - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
Cell - Interface in org.apache.hadoop.hbase
The unit of storage in HBase consisting of the following fields:
CELL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
CELLBLOCKCODECCLASS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
CELLBLOCKCOMPRESSORCLASS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
CELLBLOCKMETA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
CELLBLOCKMETA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
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
 
CellComparator - Class in org.apache.hadoop.hbase
Compare two HBase cells.
CellComparator() - Constructor for class org.apache.hadoop.hbase.CellComparator
 
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
 
cellFromHBase(KeyValue) - 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(KeyValue[]) - 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
 
CellMessage.Cell.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
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(KeyValue) - 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 - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
cellScanner() - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
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
 
CellSetMessage.CellSet.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
CellSetMessage.CellSet.Row - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
CellSetMessage.CellSet.Row.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
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
 
CELLTYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
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
 
chance - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
CHANCE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.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.HBaseServer.Connection
 
channelRead(ReadableByteChannel, ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
This is a wrapper around ReadableByteChannel.read(java.nio.ByteBuffer).
channelWrite(WritableByteChannel, ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
This is a wrapper around WritableByteChannel.write(java.nio.ByteBuffer).
CHARSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
check(Put) - Method in interface org.apache.hadoop.hbase.constraint.Constraint
Check a Put to ensure it is valid for the table.
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[], byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
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(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete, AsyncMethodCallback<THBaseService.AsyncClient.checkAndDelete_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete, AsyncMethodCallback<THBaseService.AsyncClient.checkAndDelete_call>) - 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
 
checkAndDeleteDirectory(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
Attempt to delete a directory and all files under that directory.
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Mutation, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
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[], byte[], Put) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
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(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut, AsyncMethodCallback<THBaseService.AsyncClient.checkAndPut_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut, AsyncMethodCallback<THBaseService.AsyncClient.checkAndPut_call>) - 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
 
checkAndSetEnablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
Sets the specified table as ENABLING in zookeeper atomically If the table is already in ENABLING state, no operation is performed
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, long, byte, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
Keeps track of the number of versions for the columns asked for
checkColumn(byte[], int, int, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
Keeps track of the number of versions for the columns asked for
checkColumn(byte[], int, int, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
Keeps track of the number of versions for the columns asked for
checkDfsSafeMode(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Check whether dfs is in safemode.
checkDisabledAndSetEnablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
Sets the specified table as ENABLING in zookeeper atomically If the table isn't in DISABLED state, no operation is performed
checkEnabledAndSetDisablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
Sets the specified table as DISABLING in zookeeper atomically If the table isn't in ENABLED state, no operation is performed
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.
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
 
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'
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.
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.ThreadLocalEncoderPool
 
checkIOException(IOException) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
Examine passed IOException.
checkKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Checks that the given key does not violate the key order.
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.HRegionServer
 
checkOpen() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
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.ThreadLocalEncoderPool
Get the encoder attached to the current ThreadLocal, or create a new one and attach it to the current thread.
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
Deprecated.  
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 target exists.
checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface
 
checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest, RpcCallback<AccessControlProtos.CheckPermissionsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
 
checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest, RpcCallback<AccessControlProtos.CheckPermissionsResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Interface
 
checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest, RpcCallback<AccessControlProtos.CheckPermissionsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Stub
 
checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest, RpcCallback<AccessControlProtos.CheckPermissionsResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
checkReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
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.
checkReseek() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
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.
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
 
checksumType - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
checksumType - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
Checksum type
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
 
checkTableModifiable(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
checkTableModifiable(byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Check table is modifiable; i.e.
checkTables(Collection<Path>) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
Check the specified table dirs for bad hfiles.
checkThrowable(Throwable) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
Examine passed Throwable.
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
children - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
Chore - Class in org.apache.hadoop.hbase
Chore is a task performed on a period in hbase.
Chore(String, int, Stoppable) - Constructor for class org.apache.hadoop.hbase.Chore
 
Chore() - Constructor for class org.apache.hadoop.hbase.Chore
This constructor is for test only.
chore() - Method in class org.apache.hadoop.hbase.Chore
Look for chores.
chore() - Method in class org.apache.hadoop.hbase.HealthCheckChore
 
chore() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.TimeoutMonitor
 
chore() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.TimerUpdater
 
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.ClusterStatusPublisher
 
chore() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionsCleaner
 
choreForTesting() - Method in class org.apache.hadoop.hbase.Chore
 
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
 
CLASSNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
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
 
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) - 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.
cleanPreviousInstance(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
A dead server that comes back alive has a different start code.
cleanup() - Method in class org.apache.hadoop.hbase.Chore
Called when the chore has completed, allowing subclasses to cleanup any extra overhead
cleanup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
 
cleanup() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
 
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.Subprocedure
Users should override this method.
cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
 
cleanup(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
cleanup(Throwable, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
cleanup(Exception) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
Cancel threads if they haven't finished.
cleanupBulkLoad(String) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
cleanupBulkLoad(RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.BlockingInterface
 
cleanupBulkLoad(RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.CleanupBulkLoadResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
 
cleanupBulkLoad(RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.CleanupBulkLoadResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Interface
 
cleanupBulkLoad(RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.CleanupBulkLoadResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Stub
 
cleanupBulkLoad(RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.CleanupBulkLoadResponse>) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
 
cleanupCalls() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
cleanupCalls(long) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
cleanupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
clear() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
This class is immutable.
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() - Static method in class org.apache.hadoop.hbase.ipc.RequestContext
Clears out the client credentials for a given request.
clear() - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated. Clears all recorded values.
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
clear() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Clears all entries from the map.
clear() - Method in class org.apache.hadoop.hbase.regionserver.wal.LRUDictionary
 
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.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 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.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.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.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.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.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.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 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.TScan
 
clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
clear() - Method in class org.apache.hadoop.hbase.util.ByteRange
write methods
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.SoftValueSortedMap
 
clear() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
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.
clearAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
clearAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
clearArchive() - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
 
clearAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
clearAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
clearAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
clearAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
clearAtomic() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
clearAttribute() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
clearAttribute() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
clearAttribute() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clearAttributes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
clearAttributes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
clearAttrs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clearAttrs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clearAuthMethod() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
clearAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
clearBackupMasters() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
clearBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
clearBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
clearBalancerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
clearBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearBatchSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clearBigdecimalMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
clearBitwiseOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
clearBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
clearBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
clearBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
clearCache() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Clears the cache.
clearCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
clearCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clearCaches(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Clear any caches that pertain to server name sn
clearCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
clearCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
clearCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
clearCell() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
clearCellBlockCodecClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
clearCellBlockCompressorClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
clearCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
clearCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
clearCellType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
clearChance() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
clearCharset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
clearChildZNodes() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
clearClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
clearClosed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
clearCloseScanner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
clearClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
clearClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
clearClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
clearClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
clearClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
clearClusterkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
clearClusterStatus() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
clearColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
clearColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clearColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
clearColumnBuffer() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
 
clearColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
clearColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
clearColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
clearColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
clearColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
clearColumnName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
clearColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
clearColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
clearColumns() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearColumns() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clearColumnValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
clearCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
clearCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
clearComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
clearComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
clearComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
clearComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
clearComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
clearComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
clearComparatorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clearCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
clearCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
clearCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
clearCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
clearCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
clearCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
clearCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
clearCompareType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
clearCompleteSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clearCompressionCodec() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clearCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
clearConfiguration() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
clearConfiguration() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
clearCoprocessors() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
clearCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
clearCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
clearCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
clearCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
clearDataIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clearDeadNodes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
clearDeadServers() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
clearDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
clearDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
clearDeleteType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
clearDestinationServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
clearDestServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
clearDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
clearDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
clearDoNotRetry() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
clearDropDependentColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
clearEdit() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
clearEffectiveUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
clearEnable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
clearEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
clearEndKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
clearEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clearEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearEntry() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
clearEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clearErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
clearErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
clearEventTypeCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
clearException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
clearException() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
clearExceptionClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
clearExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
clearExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
clearExists() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
clearExists() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
clearExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
clearExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
clearExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
clearFamilyPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
clearFamilyPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
clearFamilyScope() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
clearFileInfoOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clearFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
clearFiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Clears all the files currently in use and returns them.
clearFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
clearFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clearFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
clearFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
clearFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
clearFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearFilterIfMissing() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
clearFilters() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
clearFirst() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
clearFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clearFirstPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
clearFlushed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
clearForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
clearForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
clearForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
clearFrom() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
clearFsToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
clearFuzzyKeysData() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
clearGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
clearGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
clearGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
clearGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
clearHbaseVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
clearHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clearHostName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
clearHostname() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
clearId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
clearId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clearIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
clearIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
clearIfOlderThanTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
clearInfoServerPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
clearInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clearInterpreterClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
clearInterpreterSpecificBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
clearIsMasterRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
clearIsShared() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
clearIssueDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
clearJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
clearJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
clearKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
clearKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
clearKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
clearKeyId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
clearKeyType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
clearKeyValueBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
clearKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
clearKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
clearLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clearLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
clearLastFlushTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
clearLatestVersionOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
clearLeastSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
clearLenAsVal() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
clearLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
clearLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
clearLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
clearLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
clearLiveNodes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
clearLiveServers() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
clearLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
clearLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clearLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
clearLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
clearLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clearLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clearLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
clearLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
clearLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
clearLongMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
clearMajor() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
clearMapEntries() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
clearMapEntry() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
clearMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
clearMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
clearMasterCoprocessors() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
clearMaxColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
clearMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
clearMaxHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
clearMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clearMaxResultSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clearMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
clearMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clearMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clearMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
clearMetaIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clearMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
clearMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
clearMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
clearMetrics() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
clearMinColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
clearMinColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
clearMoreResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
clearMostSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
clearMutateType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
clearMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
clearMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
clearMutationRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clearNextCallSeq() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
clearNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
clearNumberOfRows() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
clearNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clearOffline() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
clearOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
clearOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
clearOpenInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
clearOpeningState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
clearOperator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
clearOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
clearPageSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
clearParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
clearPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
clearPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
clearPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
clearPattern() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
clearPatternFlags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
clearPayload() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
clearPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
clearPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
clearPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
clearPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
clearPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
clearPermissions() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
clearPermissions() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
clearPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
clearPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
clearPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
clearPosition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
clearPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
clearPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
clearPrevBalanceValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
clearPrevValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
clearProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
clearProtocol() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
clearPurpose() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
clearQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
clearQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
clearQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
clearQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
clearQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
clearQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
clearQualifiers() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
clearQualifierValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
clearRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
clearReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
clearReadRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearRealUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
clearReason() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
clearRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
clearRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
clearRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
clearRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
clearRegionCache() - Method in interface org.apache.hadoop.hbase.client.HConnection
Allows flushing the region cache.
clearRegionCache(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Allows flushing the region cache of all locations that pertain to tableName
clearRegionCache() - Method in class org.apache.hadoop.hbase.client.HTable
Explicitly clears the region cache to fetch the latest value from META.
clearRegionId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
clearRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
clearRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
clearRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
clearRegionLoads() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
clearRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
clearRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
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
 
clearRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clearRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
clearRegionsInTransition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
clearRegionSpecifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearRegionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
clearRegionToFlush() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
clearReportEndTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
clearReportStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
clearRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
clearRequestParam() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
clearRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
clearRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clearRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
clearResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
clearResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
clearResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
clearResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
clearResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
clearResultSizeBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
clearRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
clearRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
clearRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
clearRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
clearRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
clearRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
clearRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
clearRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
clearRowProcessorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
clearRowProcessorInitializerMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
clearRowProcessorInitializerMessageName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
clearRowProcessorResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
clearRows() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
clearRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
clearScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
clearScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
clearScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
clearScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
clearScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
clearScanResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
clearScopeType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
clearSecond() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
clearSecondPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
clearSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
clearSerializedComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
clearSerializedFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
clearServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
clearServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
clearServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
clearServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
clearServerCurrentTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
clearServerInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
clearServerLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
clearServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
clearServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
clearServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
clearServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
clearServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
clearService() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
clearService() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
clearServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
clearSingleColumnValueFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
clearSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
clearSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
clearSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
clearSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
clearSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
clearSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
clearSnapshots() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
clearSortedPrefixes() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
clearSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
clearSpec() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
clearSplit() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
clearSplitkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
clearSplitKeys() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
clearSplitPoint() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
clearStackTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
clearStamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
clearStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
clearStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
clearStartDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
clearStartKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
clearStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
clearStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clearStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
clearState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
clearState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
clearState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
clearState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
clearStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clearStopRowKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
clearStoreFile() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
clearStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearStorefiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearStorefileSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
clearStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clearStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
clearStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clearStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearSubstr() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
clearSynchronous() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
clearTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
clearTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
clearTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
clearTableNames() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
clearTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
clearTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
clearTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
clearThreadId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
clearTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
clearTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
clearTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clearTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
clearTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
clearTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
clearTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
clearTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
clearTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
clearTimestamps() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
clearTo() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
clearToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
clearTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
clearTotalRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
clearTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clearTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
clearTraceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
clearTraceInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
clearTransitionInZK() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
clearTtl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
clearTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
clearType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
clearType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
clearUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clearUsedHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
clearUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
clearUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
clearUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
clearUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
clearUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
clearValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
clearValues() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
clearVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
clearVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
clearVersionOfClosingNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
clearVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
clearVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
clearWebuiPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
clearWriteRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clearWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
clearWriteTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
clearWriteToWAL() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
clearYetToUpdateRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
clearZNodes(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
client - Variable in class org.apache.hadoop.hbase.ipc.ProtobufRpcClientEngine
 
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_PORT_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The ZK client port key in the ZK properties map.
CLIENT_PROTOCOL_CLASS - Static variable in class org.apache.hadoop.hbase.client.HConnectionManager
Parameter name for what client protocol to use.
ClientProtocol - Interface in org.apache.hadoop.hbase.client
Protocol that a HBase client uses to communicate with a region server.
ClientProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ActionResult - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ActionResult.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ActionResultOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.BulkLoadHFileRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.BulkLoadHFileRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.BulkLoadHFileRequest.FamilyPath - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.BulkLoadHFileRequest.FamilyPathOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.BulkLoadHFileRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.BulkLoadHFileResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.BulkLoadHFileResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.BulkLoadHFileResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ClientService - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ClientService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
ClientProtos.ClientService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ClientService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ClientService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.Column - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.Column.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ColumnOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.Condition - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.Condition.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ConditionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.CoprocessorServiceCall - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.CoprocessorServiceCall.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.CoprocessorServiceCallOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.CoprocessorServiceRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.CoprocessorServiceRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.CoprocessorServiceRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.CoprocessorServiceResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.CoprocessorServiceResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.CoprocessorServiceResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.Get - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.Get.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.GetOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.GetRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.GetRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.GetRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.GetResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.GetResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.GetResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiAction - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiAction.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiActionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiGetRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiGetRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiGetRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiGetResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiGetResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiGetResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MultiResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutateRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutateRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutateRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutateResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutateResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutateResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutationProto - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutationProto.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutationProto.ColumnValue - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutationProto.ColumnValue.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutationProto.ColumnValue.QualifierValue - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutationProto.ColumnValueOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutationProto.DeleteType - Enum in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutationProto.MutationType - Enum in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.MutationProtoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.Result - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.Result.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ResultOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.Scan - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.Scan.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ScanOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ScanRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ScanRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ScanRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ScanResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ScanResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClientProtos.ScanResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClientScanner - Class in org.apache.hadoop.hbase.client
Implements the scanner interface for the HBase client.
ClientScanner(Configuration, Scan, byte[]) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
Create a new ClientScanner for the specified table.
ClientScanner(Configuration, Scan, byte[], HConnection) - 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.
ClientSnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
Class to help with dealing with a snapshot description on the client side.
ClientSnapshotDescriptionUtils() - Constructor for class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
 
ClockOutOfSyncException - Exception in org.apache.hadoop.hbase.exceptions
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.exceptions.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.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.KeyValue.RootComparator
 
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.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
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.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
 
cloneRegionInfo(HRegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
Create a new HRegionInfo from the snapshot region info.
cloneSnapshot(byte[], byte[]) - 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.
CloneSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
Handler to Clone a snapshot.
CloneSnapshotHandler(MasterServices, HBaseProtos.SnapshotDescription, HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
 
cloneTableSchema(HTableDescriptor, byte[]) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
Create a new table descriptor cloning the snapshot table schema.
close() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
close() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
close() - Method in class org.apache.hadoop.hbase.client.HTable
 
close() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Releases any resources held or pending changes in internal buffers.
close() - Method in class org.apache.hadoop.hbase.client.HTablePool
Closes all the HTable instances , belonging to all tables in the table pool.
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 class org.apache.hadoop.hbase.fs.HFileSystem
Close this filesystem object
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.DoubleOutputStream
 
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(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 class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
 
close() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
Close the connection.
close() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
 
close() - Method in class org.apache.hadoop.hbase.ipc.ProtobufRpcClientEngine
 
close() - Method in interface org.apache.hadoop.hbase.ipc.RpcClientEngine
Shutdown this instance
close(Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
Deprecated.  
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.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.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.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 class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
 
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.Store
Close all the readers We don't need to worry about subsequent requests because the HRegion 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 interface org.apache.hadoop.hbase.regionserver.wal.HLog
Shut down the log.
close() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Reader
 
close() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Writer
 
close() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
close() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
 
close() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
 
close() - Method in class org.apache.hadoop.hbase.replication.ReplicationStateImpl
 
close() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
 
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.trace.HBaseLocalFileSpanReceiver
 
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.zookeeper.RecoverableZooKeeper
 
close() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Close the connection to ZooKeeper.
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.
closeAndDelete() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
Shut down the log and delete the log directory
closeConnection() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
closeConnection(HBaseServer.Connection) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
 
CLOSED_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
CLOSED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
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
 
closeException - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
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.
closeIStream - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
True if we should close the input stream when done.
CloseMetaHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handles closing of the root region on a region server.
CloseMetaHandler(Server, RegionServerServices, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseMetaHandler
 
CloseMetaHandler(Server, RegionServerServices, HRegionInfo, boolean, boolean, int) - 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).
closeReader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
closeReader() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
Close the current reader
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 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.CloseRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
 
closeRegion(RpcController, AdminProtos.CloseRegionRequest, RpcCallback<AdminProtos.CloseRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
closeRegion(RpcController, AdminProtos.CloseRegionRequest, RpcCallback<AdminProtos.CloseRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
 
closeRegion(RpcController, AdminProtos.CloseRegionRequest, RpcCallback<AdminProtos.CloseRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
closeRegion(AdminProtocol, 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(AdminProtocol, 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, boolean, int, 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.HRegionServer
Close a region on the region server.
CloseRegionHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handles closing of a region on a region server.
CloseRegionHandler(Server, RegionServerServices, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
 
CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, boolean, int) - 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, boolean, int, ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
 
CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, boolean, int, EventType) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
 
CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, boolean, int, EventType, ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
 
closeRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Closes the lock.
closeRegionSilentlyAndWait(HBaseAdmin, 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 class org.apache.hadoop.hbase.client.HBaseAdmin
For expert-admins.
CloseRootHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handles closing of the root region on a region server.
CloseRootHandler(Server, RegionServerServices, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRootHandler
 
CloseRootHandler(Server, RegionServerServices, HRegionInfo, boolean, boolean, int) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRootHandler
 
closeScanner(int, AsyncMethodCallback<THBaseService.AsyncClient.closeScanner_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
closeScanner(int, AsyncMethodCallback<THBaseService.AsyncClient.closeScanner_call>) - 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
 
CLOSESCANNER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
CLOSESTROWBEFORE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
CLOSESTROWBEFORE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
closeTablePool(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
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
See HTablePool.closeTablePool(String).
closing - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
CLOSING_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
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
 
ClusterId - Class in org.apache.hadoop.hbase
The identifier for this cluster.
ClusterId() - Constructor for class org.apache.hadoop.hbase.ClusterId
New ClusterID.
clusterId - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
CLUSTERID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
CLUSTERID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
CLUSTERID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
ClusterIdProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClusterIdProtos.ClusterId - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClusterIdProtos.ClusterId.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClusterIdProtos.ClusterIdOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
clusterIdZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
CLUSTERKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
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
 
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. Used by Writables and Writables are going away.
ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, Map<String, RegionState>, String[], Boolean) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
 
CLUSTERSTATUS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
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
 
ClusterStatusProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClusterStatusProtos.ClusterStatus - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClusterStatusProtos.ClusterStatus.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClusterStatusProtos.ClusterStatusOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClusterStatusProtos.LiveServerInfo - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClusterStatusProtos.LiveServerInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClusterStatusProtos.LiveServerInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClusterStatusProtos.RegionInTransition - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClusterStatusProtos.RegionInTransition.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClusterStatusProtos.RegionInTransitionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ClusterStatusProtos.RegionState - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClusterStatusProtos.RegionState.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ClusterStatusProtos.RegionState.State - Enum in org.apache.hadoop.hbase.protobuf.generated
 
ClusterStatusProtos.RegionStateOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
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 - 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.
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.
Codec - Interface in org.apache.hadoop.hbase.codec
Encoder/Decoder for Cell.
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
 
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".
CollectionBackedScanner - Class in org.apache.hadoop.hbase.util
Utility scanner that wraps a sortable collection and serves as a KeyValueScanner.
CollectionBackedScanner(SortedSet<KeyValue>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
CollectionBackedScanner(SortedSet<KeyValue>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
CollectionBackedScanner(List<KeyValue>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
CollectionBackedScanner(List<KeyValue>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
CollectionBackedScanner(KeyValue.KVComparator, KeyValue...) - 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 (:)
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.protobuf.generated.ClientProtos.Get
 
COLUMN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
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
Deprecated. space delimited list of columns
COLUMN_VALUE - Static variable in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
 
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
 
ColumnCount - Class in org.apache.hadoop.hbase.regionserver
Simple wrapper for a byte buffer and a counter.
ColumnCount(byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
Constructor
ColumnCount(byte[], int) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
Constructor
ColumnCount(byte[], int, int, int) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
Constuctor
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
 
COLUMNFAMILIES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
COLUMNFAMILIES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
COLUMNFAMILIES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
columnFamily - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
columnFamily - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
COLUMNFAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
COLUMNFAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
ColumnNodeReader - Class in org.apache.hadoop.hbase.codec.prefixtree.decode.column
 
ColumnNodeReader(byte[], boolean) - 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
 
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, boolean) - 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
 
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
 
COLUMNQUALIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
COLUMNQUALIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.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[], boolean) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
construct
columns - Variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Deprecated.  
columns - Variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
The grouping columns.
columns - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
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
 
ColumnSchemaMessage.ColumnSchema.Attribute - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
ColumnSchemaMessage.ColumnSchema.Attribute.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
ColumnSchemaMessage.ColumnSchema.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
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, boolean) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
 
ColumnTracker - Interface in org.apache.hadoop.hbase.regionserver
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.
COLUMNVALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
columnValues - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
columnValues - Variable in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
CombinedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
CombinedBlockCache is an abstraction layer that combines LruBlockCache and BucketCache.
CombinedBlockCache(LruBlockCache, BucketCache) - Constructor for 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
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
 
compact(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a table or an individual region.
compact(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a table or an individual region.
compact(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a column family within a table or region.
compact(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a column family within a table or region.
compact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
Runs the compaction based on current selection.
compact(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
Do a minor/major compaction on an explicit set of storefiles from a Store.
compact(CompactionRequest) - 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(CompactionContext, Store) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
compact(CompactionContext) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Compact the StoreFiles.
compact(CompactionContext) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
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
 
compactForTesting(Collection<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
Compact a list of files for testing.
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_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
 
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
 
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
 
COMPACTIONSTATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
COMPACTIONSTATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
CompactionTool - Class in org.apache.hadoop.hbase.regionserver
 
CompactionTool() - Constructor for class org.apache.hadoop.hbase.regionserver.CompactionTool
 
Compactor - 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
TODO: Replace this with CellOutputStream when StoreFile.Writer uses cells.
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
 
compactRecentForTestingAssumingDefaultPolicy(int) - Method in class org.apache.hadoop.hbase.regionserver.HStore
This method tries to compact N recent files for testing.
compactRegion(RpcController, AdminProtos.CompactRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
 
compactRegion(RpcController, AdminProtos.CompactRegionRequest, RpcCallback<AdminProtos.CompactRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
compactRegion(RpcController, AdminProtos.CompactRegionRequest, RpcCallback<AdminProtos.CompactRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
 
compactRegion(RpcController, AdminProtos.CompactRegionRequest, RpcCallback<AdminProtos.CompactRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
compactRegion(RpcController, AdminProtos.CompactRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Compact a region 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(boolean) - 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
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
COMPARABLE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
COMPARABLE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
COMPARABLE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
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.hfile.AbstractHFileReader
Key comparator
comparator - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Key comparator.
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 - 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.SoftValueSortedMap
 
comparator() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
COMPARATOR - Static variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.ZNodeComparator
 
COMPARATOR_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
COMPARATOR_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
COMPARATOR_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
COMPARATORCLASSNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
ComparatorProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.BinaryComparator - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.BinaryComparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.BinaryComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.BinaryPrefixComparator - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.BinaryPrefixComparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.BinaryPrefixComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.BitComparator - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.BitComparator.BitwiseOp - Enum in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.BitComparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.BitComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.ByteArrayComparable - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.ByteArrayComparable.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.ByteArrayComparableOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.Comparator - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.Comparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.ComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.NullComparator - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.NullComparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.NullComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.RegexStringComparator - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.RegexStringComparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.RegexStringComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.SubstringComparator - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.SubstringComparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ComparatorProtos.SubstringComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparator
 
compare(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
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.KeyComparator
 
compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
 
compare(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compare(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.RowComparator
 
compare(RegionPlan, RegionPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator
 
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(String, String) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.ZNodeComparator
 
compareColumns(byte[], int, int, int, byte[], int, int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
 
compareColumns(KeyValue, byte[], int, 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.
COMPAREFILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
COMPAREFILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
COMPAREFILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
COMPAREFILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
COMPAREFILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
compareIgnoringPrefix(int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
Compare the two key-values, ignoring the prefix of the given length that is known to be the same between the two.
compareIgnoringPrefix(int, T, int, int, T, int, int) - Method in interface org.apache.hadoop.hbase.KeyValue.SamePrefixComparator
Compare two keys assuming that the first n bytes are the same.
compareOp - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
 
compareOp - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
COMPAREOP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
COMPAREOP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
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.
compareRowid(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.MetaKeyComparator
 
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
 
compareRows(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareRows(KeyValue, short, KeyValue, short) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
compareRows(KeyValue, byte[]) - 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
 
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.MetaKeyComparator
 
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.RootKeyComparator
 
compareStatic(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
 
compareTimestamps(KeyValue, KeyValue) - 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.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[]) - 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(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(BlockCacheColumnFamilySummary) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
 
compareTo(CachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
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(TableSplit) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
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(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(HLogKey) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
 
compareTo(ServerName) - Method in class org.apache.hadoop.hbase.ServerName
 
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.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.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.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.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.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.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(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(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
compareTo(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
compareTo(TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
compareTo(TTimeRange) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
compareTo(ByteRange) - Method in class org.apache.hadoop.hbase.util.ByteRange
Bitwise comparison of each byte in the 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.
compareToCurrentToken(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
Compare only the bytes within the window of the current token
COMPARETYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
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.
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
 
compileRows() - 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.
completeCacheFlush(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
Complete the cache flush.
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.snapshot.CloneSnapshotHandler
 
completeMemstoreInsert(MultiVersionConsistencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
Complete a MultiVersionConsistencyControl.WriteEntry that was created by MultiVersionConsistencyControl.beginMemstoreInsert().
completeSequenceId - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
COMPLETESEQUENCEID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
completeSnapshot(Path, Path, FileSystem) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
Reset the manager to allow another snapshot to proceed
completeSnapshot(HBaseProtos.SnapshotDescription, Path, Path, FileSystem) - 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'.
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, RawComparator<byte[]>) - 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.
compressAfterEncoding(byte[], BlockType) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
compressAfterEncoding(byte[], BlockType, byte[]) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
compressAlgo - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Filled when we read in the trailer.
compressAlgo - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
The compression algorithm used.
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.io.hfile.HFile.WriterFactory
 
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
 
COMPRESSIONCODEC_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
compressionContext - Variable in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
Compression context to use reading.
CompressionTest - Class in org.apache.hadoop.hbase.util
Compression validation test.
CompressionTest() - Constructor for class org.apache.hadoop.hbase.util.CompressionTest
 
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
 
computeBitSize(long, double) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
computeCost(Map<HRegionInfo, ServerName>, Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
This is the main cost function.
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(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.
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
CONDITION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
conf - Variable in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectable
 
conf - Variable in class org.apache.hadoop.hbase.client.MetaScanner.DefaultMetaScannerVisitor
 
conf - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
conf - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
conf - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
conf - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
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.HRegionServer
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
 
conf - Variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
conf - Variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
configs - Variable in class org.apache.hadoop.hbase.CompoundConfiguration
 
CONFIGURATION - Static variable in class org.apache.hadoop.hbase.HConstants
 
CONFIGURATION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
CONFIGURATION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
Deprecated.  
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
Deprecated.  
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.ConstantSizeRegionSplitPolicy
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
 
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
Configure a MapReduce Job to perform an incremental load into the given table.
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.
connect(HConnection) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectable
 
connect(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
connect(boolean) - Method in class org.apache.hadoop.hbase.client.ServerCallable
Connect to the server hosting region with row from tablename.
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.ServerCallable
 
connection - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
connectionList - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
connections - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
ConnectionUtils - Class in org.apache.hadoop.hbase.client
Utility used by client connections such as HConnection and ServerCallable
ConnectionUtils() - Constructor for class org.apache.hadoop.hbase.client.ConnectionUtils
 
connectToPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
This method connects this cluster to another one and registers it in this region server's replication znode
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
 
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.exceptions
Exception that a user defined constraint throws on failure of a Put.
ConstraintException() - Constructor for exception org.apache.hadoop.hbase.exceptions.ConstraintException
 
ConstraintException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConstraintException
 
ConstraintException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.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.BackupMasterListTmpl
 
constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterListTmpl
 
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.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
 
constructInputStream(DataInput) - Static method in class org.apache.hadoop.hbase.io.DataInputInputStream
Construct an InputStream from the given DataInput.
constructMaster(Class<? extends HMaster>, Configuration) - 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) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Utility for constructing an instance of the passed HRegionServer class.
contains(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
Check to see if the passed file name is contained in any of the snapshots.
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(byte[], int, int, ByteBuffer) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
contains(byte[], int, int, byte[], 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(Object) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
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<KeyValue>, Collection<KeyValue>) - 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.regionserver.LruHashMap
Checks whether there is a value in the map for the specified key.
containsKey(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
containsKey(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
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.
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
 
containsValue(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
CONTEXT - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
controllerConnectionFailure(String, IOException) - 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.
convert() - Method in class org.apache.hadoop.hbase.ClusterStatus
Convert a ClusterStatus to a protobuf ClusterStatus
convert(ClusterStatusProtos.ClusterStatus) - Static method in class org.apache.hadoop.hbase.ClusterStatus
Convert a protobuf ClusterStatus to a ClusterStatus
convert(HBaseProtos.ColumnFamilySchema) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
convert() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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
 
convert(HBaseProtos.TableSchema) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
 
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(DeserializationException) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Convert a DeserializationException to a more palatable KeeperException.
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
convertKvToByteBuffer(List<KeyValue>, boolean) - Static method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
Convert list of KeyValues to byte buffer.
convertThrowableToIOE(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
convertThrowableToIOE(Throwable, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
convertToBigInteger(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
Returns the BigInteger represented by the byte array
convertToByte(BigInteger, int) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
Returns the bytes corresponding to the BigInteger
convertToByte(BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
Returns the bytes corresponding to the BigInteger
convertToBytes(BigInteger[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
Returns an array of bytes corresponding to an array of BigIntegers
coordinator - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
 
Coprocessor - Interface in org.apache.hadoop.hbase
Coprocess interface.
Coprocessor.State - Enum in org.apache.hadoop.hbase
Lifecycle state of a given coprocessor instance.
CoprocessorClassLoader - Class in org.apache.hadoop.hbase.coprocessor
ClassLoader used to load Coprocessor instances.
CoprocessorClassLoader(List<URL>, ClassLoader) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorClassLoader
Creates a CoprocessorClassLoader that loads classes from the given paths.
CoprocessorEnvironment - Interface in org.apache.hadoop.hbase
Coprocessor environment state.
CoprocessorException - Exception in org.apache.hadoop.hbase.exceptions
Thrown if a coprocessor encounters any exception.
CoprocessorException() - Constructor for exception org.apache.hadoop.hbase.exceptions.CoprocessorException
Default Constructor
CoprocessorException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.exceptions.CoprocessorException
Constructor with a Class object and exception message.
CoprocessorException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.CoprocessorException
Constructs the exception and supplies a string as the message
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() - 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
 
coprocessors - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Ordered set of loaded coprocessors with lock
COPROCESSORS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
coprocessorService() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Creates and returns a RpcChannel instance connected to the active master.
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 interface org.apache.hadoop.hbase.client.HTableInterface
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.HTableInterface
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.HTableInterface
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.
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
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.
copyFromBufferToBuffer(ByteBuffer, ByteBuffer, 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
 
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
 
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
copyQualifierTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
 
copyQueuesFromRS(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
This methods copies all the hlogs queues from another region server and returns them all sorted per peer cluster (appended with the dead server's znode)
copyQueuesFromRSUsingMulti(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
It "atomically" copies all the hlogs queues from another region server and returns them all sorted per peer cluster (appended with the dead server's znode).
CopyRecoveredEditsTask - Class in org.apache.hadoop.hbase.snapshot
Copy over each of the files in a region's recovered.edits directory to the region's snapshot directory.
CopyRecoveredEditsTask(HBaseProtos.SnapshotDescription, ForeignExceptionDispatcher, FileSystem, Path, Path) - Constructor for class org.apache.hadoop.hbase.snapshot.CopyRecoveredEditsTask
 
copyRowTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
copyTo
copyServerNames() - Method in class org.apache.hadoop.hbase.master.DeadServer
 
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() - Constructor for class org.apache.hadoop.hbase.mapreduce.CopyTable
 
copyToNewArrays(Collection<ByteRange>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeTool
 
copyToNewByteArray(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
copyToNewByteBuffer(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
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.exceptions
Exception thrown when the found snapshot info from the filesystem is not valid
CorruptedSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.CorruptedSnapshotException
 
CorruptedSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.exceptions.CorruptedSnapshotException
Snapshot was corrupt for some reason
CorruptedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.CorruptedSnapshotException
 
CorruptHFileException - Exception in org.apache.hadoop.hbase.exceptions
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.exceptions.CorruptHFileException
 
CorruptHFileException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.CorruptHFileException
 
COUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
counter - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
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
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
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_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
 
create(Configuration) - Static method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
Create an archive tracker for the passed in server
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(BlockCacheColumnFamilySummary) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
Creates a new BlockCacheSummaryEntry
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, String, String, String) - 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(MetricsMasterWrapper) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSourceFactory
 
create(MetricsMasterWrapper) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl
 
create(HRegion, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
Create the RegionSplitPolicy configured for the given table.
create(Store, Configuration, KeyValue.KVComparator) - Static method in class org.apache.hadoop.hbase.regionserver.StoreEngine
Create the StoreEngine configured for the given Store.
create(UserGroupInformation) - Static method in class org.apache.hadoop.hbase.security.User
Wraps an underlying UserGroupInformation instance.
create(FileSystem, Path, FsPermission) - 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(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
NONSEQUENTIAL create is idempotent operation.
CREATE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
 
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
 
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.
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
 
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
 
createCellScanner(List<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<? extends Cell>>) - Static method in class org.apache.hadoop.hbase.CellUtil
Flatten the map of cells out under the CellScanner
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.
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
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.
createCompressionStream(OutputStream, Compressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
createConfigurationSubset() - Method in class org.apache.hadoop.hbase.master.HMaster
 
createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Create a new HConnection instance using the passed conf instance.
createConnection(HBaseClient.ConnectionId, Codec, CompressionCodec) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
Creates a connection.
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.
createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
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(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
Calls ServerManager.createDestinationServersList(org.apache.hadoop.hbase.ServerName) without server to exclude.
createEncoder(String) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
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.
createExceptionString(Class) - Static method in class org.apache.hadoop.hbase.CompatibilityFactory
 
createFileScanners(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
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.KeyValue
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
Create a KeyValue that is smaller than all other possible KeyValues for the given row.
createFirstOnRow(byte[], int, short) - Static method in class org.apache.hadoop.hbase.KeyValue
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.KeyValue
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.KeyValue
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.KeyValue
 
createFirstOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
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.KeyValue
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.KeyValue
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(long) - Method in class org.apache.hadoop.hbase.KeyValue
Creates the first KV with the row/family/qualifier of this KV and the given timestamp.
createFromFileInfo(HFile.FileInfo, DataBlockEncoding) - 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
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.
createFromStoreFilePath(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
Construct a BlockCacheSummaryEntry from a full StoreFile Path

The path is expected to be in the format of...
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
Deprecated. 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.
createHDFSRegionDir(Configuration, HRegionInfo, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
Creates, flushes, and closes a new region.
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(String, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink name
createHLog(FileSystem, Path, String, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogFactory
 
createHLog(FileSystem, Path, String, String, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogFactory
 
createHLog(FileSystem, Path, String, Configuration, List<WALActionsListener>, String) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogFactory
 
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, HLog, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Convenience method creating new HRegions.
createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, HLog, boolean, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Convenience method creating new HRegions.
createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, HLog) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
 
createHTable(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
 
createHTableInterface(Configuration, byte[]) - Method in class org.apache.hadoop.hbase.client.HTableFactory
 
createHTableInterface(Configuration, byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
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
 
createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
createKey(String) - Static method in class org.apache.hadoop.hbase.util.Keying
Makes a key out of passed URI for use as row name or column qualifier.
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
 
createLastOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue that is last on the specified row id.
createLastOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
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.
createLastOnRowCol() - Method in class org.apache.hadoop.hbase.KeyValue
Similar to KeyValue.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).
createLease(String, int, LeaseListener) - Method in class org.apache.hadoop.hbase.regionserver.Leases
Obtain a lease.
createLogSplitter(Configuration, Path, Path, Path, FileSystem) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
Create a new HLogSplitter using the given Configuration and the hbase.hlog.splitter.impl property to derived the instance class to use.
createMasterThread(Configuration, Class<? extends HMaster>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
Creates a JVMClusterUtil.MasterThread.
createMetaHLog(FileSystem, Path, String, Configuration, List<WALActionsListener>, String) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogFactory
 
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
 
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.
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) - 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
 
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
 
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.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, CacheConfig) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
createReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
createReader(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogFactory
Create a reader for the WAL.
createReaderWithEncoding(FileSystem, Path, CacheConfig, DataBlockEncoding) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
createReaderWithEncoding(FileSystem, Path, FSDataInputStream, FSDataInputStream, long, CacheConfig, DataBlockEncoding, boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
 
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
Builds a TableRecordReader.
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
 
createRegionLoad(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
createRegionName(byte[], byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(byte[], byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Make a region name of passed parameters.
createRegionName(byte[], byte[], byte[], 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.
createRegionServerThread(Configuration, Class<? extends HRegionServer>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
Creates a JVMClusterUtil.RegionServerThread.
createRegionState(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
Add a region to RegionStates.
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
 
createRPCStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
createScanner(Store, List<StoreFileScanner>, ScanType, long, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
createSecretKey(byte[]) - Static method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
createSeeker(RawComparator<byte[]>, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
Is this the correct handling of an illegal comparator? How to prevent that from getting all the way to this point.
createSeeker(RawComparator<byte[]>, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
createSeeker(RawComparator<byte[]>, boolean) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Create a HFileBlock seeker which find KeyValues within a block.
createSeeker(RawComparator<byte[]>, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
 
createSeeker(RawComparator<byte[]>, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
 
createSeeker(RawComparator<byte[]>, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
 
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
 
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.
createStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
Deprecated.  
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static 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(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.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)
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[][]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
createTable(RpcController, MasterAdminProtos.CreateTableRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
createTable(HTableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Create a table using the given table definition.
createTable(RpcController, MasterAdminProtos.CreateTableRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
createTable(RpcController, MasterAdminProtos.CreateTableRequest, RpcCallback<MasterAdminProtos.CreateTableResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
createTable(RpcController, MasterAdminProtos.CreateTableRequest, RpcCallback<MasterAdminProtos.CreateTableResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
createTable(RpcController, MasterAdminProtos.CreateTableRequest, RpcCallback<MasterAdminProtos.CreateTableResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
Creates a new table.
createTable(ByteBuffer, List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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.master.MasterFileSystem
Create new HTableDescriptor in HDFS.
createTableDescriptor(HTableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Create new HTableDescriptor in HDFS.
createTableDescriptor(FileSystem, Path, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Create new HTableDescriptor in HDFS.
createTableDescriptor(FileSystem, Path, HTableDescriptor, boolean) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Create new HTableDescriptor in HDFS.
createTableDescriptorForTableDirectory(FileSystem, Path, HTableDescriptor, boolean) - Static 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
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
 
CREATETIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
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.
createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
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.
createWriter(FileSystem, Path, FSDataOutputStream, int, Compression.Algorithm, HFileDataBlockEncoder, KeyValue.KeyComparator, ChecksumType, int, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
createWriter(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogFactory
Create a writer for the WAL.
createWriter(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
Create a new HLog.Writer for writing log splits.
createWriterInTmp(long, Compression.Algorithm, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
createWriterInTmp(long, Compression.Algorithm, boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
CREATIONTIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
CREATOR_ALL_AND_WORLD_READABLE - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
CRLF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
CurCall - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
This is set to Call object before Handler invokes an RPC and reset after the call returns.
current() - Method in interface org.apache.hadoop.hbase.CellScanner
 
current() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
 
current() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
CellScanner
CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
currentCellIndex - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
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.protobuf.generated.HBaseProtos.RegionLoad
 
CURRENTCOMPACTEDKVS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
currentPositionIsAfter(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
internal methods
currentRowNode - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
currentTimeMillis() - Method in class org.apache.hadoop.hbase.util.DefaultEnvironmentEdge
Returns the currentTimeMillis.
currentTimeMillis() - Method in interface org.apache.hadoop.hbase.util.EnvironmentEdge
Returns the currentTimeMillis.
currentTimeMillis() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
Defers to the delegate and calls the EnvironmentEdge.currentTimeMillis() method.
currentTimeMillis() - Method in class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
Returns the currentTimeMillis.
currentTimeMillis() - 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
 

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
 
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_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
 
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 - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
 
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
dataBlockReadCnt - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
 
DATAINDEXCOUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
DataInputInputStream - Class in org.apache.hadoop.hbase.io
An InputStream that wraps a DataInput.
DataInputInputStream(DataInput) - Constructor for class org.apache.hadoop.hbase.io.DataInputInputStream
 
DataOutputOutputStream - Class in org.apache.hadoop.hbase.io
OutputStream implementation that wraps a DataOutput.
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.master.handler.ServerShutdownHandler
 
deadServers - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
DEADSERVERS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
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
DebugPrint - Class in org.apache.hadoop.hbase.regionserver
 
DebugPrint() - Constructor for class org.apache.hadoop.hbase.regionserver.DebugPrint
 
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.
DECLARINGCLASS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
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.
decodeFileToFile(String, String) - Static method in class org.apache.hadoop.hbase.util.Base64
Reads infile and decodes it to outfile.
decodeFromFile(String) - Static method in class org.apache.hadoop.hbase.util.Base64
Convenience method for reading a base64-encoded file and decoding it.
decodeKeyValues(DataInputStream, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
 
decodeKeyValues(DataInputStream, int, int, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
I don't think this method is called during normal HBase operation, so efficiency is not important.
decodeKeyValues(DataInputStream, int, int, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
decodeKeyValues(DataInputStream, boolean) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Decode.
decodeKeyValues(DataInputStream, int, int, boolean) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Uncompress.
decodeKeyValues(DataInputStream, int, int, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
 
decodeKeyValues(DataInputStream, int, int, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
 
decodeKeyValues(DataInputStream, int, int, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
 
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
 
decodeToFile(String, String) - Static method in class org.apache.hadoop.hbase.util.Base64
Convenience method for decoding data to a file.
decodeToObject(String) - Static method in class org.apache.hadoop.hbase.util.Base64
Attempts to decode Base64 data and deserialize a Java Object within.
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
decrement() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
Decrement the current version count
decRpcCount() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.MemStore
 
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.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.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.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.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.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.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 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.TPut
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.ByteRange
Create a new ByteRange with new backing byte[] and copy the state of this range into the new range.
deepCopySubRangeTo(int, int, byte[], int) - Method in class org.apache.hadoop.hbase.util.ByteRange
Wrapper for System.arraycopy.
deepCopyTo(byte[], int) - Method in class org.apache.hadoop.hbase.util.ByteRange
Wrapper for System.arraycopy.
deepCopyToNewArray() - Method in class org.apache.hadoop.hbase.util.ByteRange
Instantiate a new byte[] with exact length, which is at least 24 bytes + length.
DEFAULT_ADMIN_PROTOCOL_CLASS - Static variable in class org.apache.hadoop.hbase.client.HConnectionManager
Default admin protocol class name.
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_BLOCKSIZE_SMALL - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
 
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_COMBINED_PERCENTAGE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
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_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_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_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_CHECKSUM_TYPE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
 
DEFAULT_CLIENT_PROTOCOL_CLASS - Static variable in class org.apache.hadoop.hbase.client.HConnectionManager
Default client protocol class name.
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_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_COMPRESSED_CACHE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
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_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default data block encoding algorithm.
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_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 value of HConstants.HBASE_CLIENT_PAUSE.
DEFAULT_HBASE_CLIENT_PREFETCH_LIMIT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_CLIENT_PREFETCH_LIMIT.
DEFAULT_HBASE_CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_CLIENT_RETRIES_NUMBER.
DEFAULT_HBASE_CLIENT_RPC_MAXATTEMPTS - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_CLIENT_RPC_MAXATTEMPTS.
DEFAULT_HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for HConstants.HBASE_CLIENT_SCANNER_CACHING
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 value of HConstants.HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD.
DEFAULT_HBASE_CONFIG_READ_ZOOKEEPER_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_META_SCANNER_CACHING.
DEFAULT_HBASE_RPC_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_RPC_TIMEOUT_KEY
DEFAULT_HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_SERVER_PAUSE.
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_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_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 serve from memory or not.
DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
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_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_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_MAX_AGE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
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_RESUBMIT - Static variable in class org.apache.hadoop.hbase.master.SplitLogManager
 
DEFAULT_MAX_WAIT_TIME - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
By default, wait 60 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_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_READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Constant that denotes whether the table is READONLY by default and is false
DEFAULT_REGIONSERVER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
default port for region server web api
DEFAULT_REGIONSERVER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Default port region server listens on.
DEFAULT_REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Default scope.
DEFAULT_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Strings
 
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_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_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_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_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.master.SplitLogManager
 
DEFAULT_TIMESTAMP_COLUMN_INDEX - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
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_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_ZK_RETRIES - Static variable in class org.apache.hadoop.hbase.master.SplitLogManager
 
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
DefaultCompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
The default algorithm for selecting files for compaction.
DefaultCompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactionPolicy
 
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
 
DefaultEnvironmentEdge - Class in org.apache.hadoop.hbase.util
Default implementation of an environment edge.
DefaultEnvironmentEdge() - Constructor for class org.apache.hadoop.hbase.util.DefaultEnvironmentEdge
 
DefaultLoadBalancer - Class in org.apache.hadoop.hbase.master.balancer
Makes decisions about the placement and movement of Regions across RegionServers.
DefaultLoadBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.DefaultLoadBalancer
 
defaultPool(String, long, int, long) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
Default thread pool for the procedure
defaultPool(long, long, int, String) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureMember
 
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
 
DEFERRED_LOG_FLUSH - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used by HBase Shell interface to access this metadata attribute which denotes if the deferred log flush option is enabled
Delayable - Interface in org.apache.hadoop.hbase.ipc
A call whose response can be delayed by the server.
delayResponse - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
delayReturnValue - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
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, 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 interface org.apache.hadoop.hbase.client.HTableInterface
Deletes the specified cells/row.
delete(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
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
 
delete(RpcController, BulkDeleteProtos.BulkDeleteRequest, RpcCallback<BulkDeleteProtos.BulkDeleteResponse>) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService.Interface
 
delete(RpcController, BulkDeleteProtos.BulkDeleteRequest, RpcCallback<BulkDeleteProtos.BulkDeleteResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService.Stub
 
delete(Delete, boolean) - 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(String) - 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(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_COLUMN_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
 
DELETE_FAMILY_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Delete Family Count in FileInfo
DELETE_FAMILY_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
 
DELETE_FAMILY_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
 
DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
DELETE_MULTIPLE_VERSIONS_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
 
DELETE_ONE_VERSION_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
 
DELETE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
 
DELETE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
 
deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
deleteAllConnections() - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Delete information for all connections.
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>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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.
deleteClosedNode(ZooKeeperWatcher, String) - 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) - 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) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the latest version of the specified column.
deleteColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the specified version of the specified column.
deleteColumn(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete a column from a table.
deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete a column from a table.
deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
deleteColumn(RpcController, MasterAdminProtos.DeleteColumnRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
Delete column of a table
deleteColumn(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Delete a column from an existing table
deleteColumn(RpcController, MasterAdminProtos.DeleteColumnRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
deleteColumn(RpcController, MasterAdminProtos.DeleteColumnRequest, RpcCallback<MasterAdminProtos.DeleteColumnResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
deleteColumn(RpcController, MasterAdminProtos.DeleteColumnRequest, RpcCallback<MasterAdminProtos.DeleteColumnResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
deleteColumn(RpcController, MasterAdminProtos.DeleteColumnRequest, RpcCallback<MasterAdminProtos.DeleteColumnResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
deleteColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column.
deleteColumns(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.
deleteConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Delete connection information for the instance specified by configuration.
deleteDaughtersReferencesInParent(CatalogTracker, HRegionInfo) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Deletes daughters references in offlined split parent.
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
Delete all versions of all columns of the specified family.
deleteFamily(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.
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
 
deleteFromHBase(Delete) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
 
deleteFromMetaTable(CatalogTracker, List<Delete>) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Delete the passed deletes from the .META. 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
deleteMergeQualifiers(CatalogTracker, HRegionInfo) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Deletes merge qualifiers for the specified merged region.
deleteMetaLocation(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
Deletes the location of .META. in ZooKeeper.
deleteMultiple(ByteBuffer, List<TDelete>, AsyncMethodCallback<THBaseService.AsyncClient.deleteMultiple_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
deleteMultiple(ByteBuffer, List<TDelete>, AsyncMethodCallback<THBaseService.AsyncClient.deleteMultiple_call>) - 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
deleteNode(ZooKeeperWatcher, String, EventType) - 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) - 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.
deleteOfflineNode(ZooKeeperWatcher, String) - 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.
deleteOpenedNode(ZooKeeperWatcher, String) - 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.
deleteOwnRSZNode() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Delete this cluster's queues
deleteReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
Delete this file
deleteRegion(CatalogTracker, HRegionInfo) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Deletes the specified region from META.
deleteRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
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(CatalogTracker, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Deletes the specified regions from META.
deleteRsQueues(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Recursive deletion of all znodes in specified rs' znode
deletes - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
list of TDeletes to delete
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<THBaseService.AsyncClient.deleteSingle_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
deleteSingle(ByteBuffer, TDelete, AsyncMethodCallback<THBaseService.AsyncClient.deleteSingle_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
deleteSingle - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
the TDelete to execute if the check succeeds
deleteSingle(ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
deleteSingle - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
the TDelete to delete
deleteSingle(ByteBuffer, TDelete) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
Deletes as specified by the TDelete.
deleteSingle(ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
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, MasterAdminProtos.DeleteSnapshotRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
Execute Delete Snapshot operation.
deleteSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Delete the specified snapshot
deleteSnapshot(RpcController, MasterAdminProtos.DeleteSnapshotRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
deleteSnapshot(RpcController, MasterAdminProtos.DeleteSnapshotRequest, RpcCallback<MasterAdminProtos.DeleteSnapshotResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
deleteSnapshot(RpcController, MasterAdminProtos.DeleteSnapshotRequest, RpcCallback<MasterAdminProtos.DeleteSnapshotResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
deleteSnapshot(RpcController, MasterAdminProtos.DeleteSnapshotRequest, RpcCallback<MasterAdminProtos.DeleteSnapshotResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
deleteSource(String, boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Delete a complete queue of hlogs
deleteStaleConnection(HConnection) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Delete stale connection information for the instance specified by configuration.
deleteTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deletes a table.
deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deletes a table.
deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
deleteTable(RpcController, MasterAdminProtos.DeleteTableRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
deleteTable(byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Delete a table
deleteTable(RpcController, MasterAdminProtos.DeleteTableRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
deleteTable(RpcController, MasterAdminProtos.DeleteTableRequest, RpcCallback<MasterAdminProtos.DeleteTableResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
deleteTable(RpcController, MasterAdminProtos.DeleteTableRequest, RpcCallback<MasterAdminProtos.DeleteTableResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
deleteTable(RpcController, MasterAdminProtos.DeleteTableRequest, RpcCallback<MasterAdminProtos.DeleteTableResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
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) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
deleteTableDescriptorIfExists(String, Configuration) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Deletes a table's directory from the file system if exists.
DeleteTableHandler - Class in org.apache.hadoop.hbase.master.handler
 
DeleteTableHandler(byte[], Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
 
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.
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.thrift2.generated.TDelete
 
DELETETYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
DELETETYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
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
 
deny(String, String, User, Permission.Action, byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
 
deny(String, String, User, Permission.Action, byte[], 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
 
descendToLastRowFromCurrentPosition() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayReversibleScanner
 
description - Variable in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
Deprecated.  
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
 
DESTINATIONSERVER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
destroy() - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
 
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.
DESTSERVERNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
detail(String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
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
 
DirectMemoryUtils() - Constructor for class org.apache.hadoop.hbase.util.DirectMemoryUtils
 
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.
disable() - Static method in class org.apache.hadoop.hbase.regionserver.DebugPrint
 
disableConstraint(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Disable the given Constraint.
DISABLED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
 
DISABLED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
 
DISABLED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
 
DisabledTableSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
Take a snapshot of a disabled table.
DisabledTableSnapshotHandler(HBaseProtos.SnapshotDescription, MasterServices) - 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.regionserver.wal.HLogPrettyPrinter
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 class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Disable replication to the peer
disableTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Disable table and wait on completion.
disableTable(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
disableTable(RpcController, MasterAdminProtos.DisableTableRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
disableTable(byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Disable an existing table
disableTable(RpcController, MasterAdminProtos.DisableTableRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
disableTable(RpcController, MasterAdminProtos.DisableTableRequest, RpcCallback<MasterAdminProtos.DisableTableResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
disableTable(RpcController, MasterAdminProtos.DisableTableRequest, RpcCallback<MasterAdminProtos.DisableTableResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
disableTable(RpcController, MasterAdminProtos.DisableTableRequest, RpcCallback<MasterAdminProtos.DisableTableResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
disableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
disableTableAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTableAsync(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Starts the disable of a table.
DisableTableHandler - Class in org.apache.hadoop.hbase.master.handler
Handler to run disable of a table.
DisableTableHandler(Server, byte[], CatalogTracker, AssignmentManager, TableLockManager, boolean) - Constructor for class org.apache.hadoop.hbase.master.handler.DisableTableHandler
 
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.regionserver.wal.HLogPrettyPrinter
turns value output off
DISABLING_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
 
discardCurrentRowNode(boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
diskToCacheFormat(HFileBlock, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Converts a block from the on-disk format to the in-cache format.
diskToCacheFormat(HFileBlock, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
diskToCacheFormat(HFileBlock, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
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) - Constructor for class org.apache.hadoop.hbase.master.handler.DispatchMergingRegionHandler
 
dispatchMergingRegions(RpcController, MasterAdminProtos.DispatchMergingRegionsRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
dispatchMergingRegions(HRegionInfo, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
dispatchMergingRegions(HRegionInfo, HRegionInfo, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Merge two regions.
dispatchMergingRegions(RpcController, MasterAdminProtos.DispatchMergingRegionsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
dispatchMergingRegions(RpcController, MasterAdminProtos.DispatchMergingRegionsRequest, RpcCallback<MasterAdminProtos.DispatchMergingRegionsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
dispatchMergingRegions(RpcController, MasterAdminProtos.DispatchMergingRegionsRequest, RpcCallback<MasterAdminProtos.DispatchMergingRegionsResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
dispatchMergingRegions(RpcController, MasterAdminProtos.DispatchMergingRegionsRequest, RpcCallback<MasterAdminProtos.DispatchMergingRegionsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
dispose() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
Release resources used by wrapped saslClient
DISTRIBUTED_LOG_SPLITTING_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key that enables distributed log splitting
divideForAvg(BigDecimal, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
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 data values.
doBatchOp(ClientProtos.MultiResponse.Builder, HRegion, List<ClientProtos.MutationProto>, CellScanner) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Execute a list of Put/Delete mutations.
doBulkLoad(Path, HTable) - 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
 
doesIncludeMemstoreTS() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
 
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(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.Scan
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() - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
 
done() - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
Done when there are no more columns to match against.
done() - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
We can never know a-priori if we are done, so always return false.
DONE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
DONE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
DONE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
 
doneBulkLoad(byte[], String) - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener
Called after a successful HFile load
doneWithColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
This method is used to inform the column tracker that we are done with this column.
DONOTRETRY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
DoNotRetryIOException - Exception in org.apache.hadoop.hbase.exceptions
Subclass if exception is not meant to be retried: e.g.
DoNotRetryIOException() - Constructor for exception org.apache.hadoop.hbase.exceptions.DoNotRetryIOException
default constructor
DoNotRetryIOException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.DoNotRetryIOException
 
DoNotRetryIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.DoNotRetryIOException
 
DoNotRetryIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.DoNotRetryIOException
 
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
 
doRealSeek(KeyValueScanner, KeyValue, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
 
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.
doSmokeTest(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
 
doStaticMain(String[]) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
Call this from the concrete tool class's main function.
DoubleBlockCache - Class in org.apache.hadoop.hbase.io.hfile
DoubleBlockCache is an abstraction layer that combines two caches, the smaller onHeapCache and the larger offHeapCache.
DoubleBlockCache(long, long, long, long, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
Default constructor.
DoubleOutputStream - Class in org.apache.hadoop.hbase.io
An output stream that writes to two streams on each operation.
DoubleOutputStream(OutputStream, OutputStream) - Constructor for class org.apache.hadoop.hbase.io.DoubleOutputStream
 
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 Runnable>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
drainTo(Collection<? super Runnable>, int) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
Driver - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
Driver() - Constructor for class org.apache.hadoop.hbase.mapred.Driver
Deprecated.  
Driver - Class in org.apache.hadoop.hbase.mapreduce
Driver for hbase mapreduce jobs.
Driver() - Constructor for class org.apache.hadoop.hbase.mapreduce.Driver
 
dropDependentColumn - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
dropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
DROPDEPENDENTCOLUMN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
DroppedSnapshotException - Exception in org.apache.hadoop.hbase.exceptions
Thrown during flush if the possibility snapshot content was not properly persisted into store files.
DroppedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.DroppedSnapshotException
 
DroppedSnapshotException() - Constructor for exception org.apache.hadoop.hbase.exceptions.DroppedSnapshotException
default constructor
dump(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
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
 
dumpQueue() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
dumps - Variable in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
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.
dumpToFile(String) - Static method in class org.apache.hadoop.hbase.regionserver.DebugPrint
 
dumpToLog() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
dumpVersionInfo(PrintWriter) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
 

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
EDIT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
EDITFILES_NAME_PATTERN - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.HLog
 
EFFECTIVEUSER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
element() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
emitRecord(String, String, OutputRecord) - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
Deprecated.  
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_RESULT - Static variable in class org.apache.hadoop.hbase.client.Result
 
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
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() - Static method in class org.apache.hadoop.hbase.regionserver.DebugPrint
 
ENABLE_DATA_FILE_UMASK - Static variable in class org.apache.hadoop.hbase.HConstants
Enable file permission modification from standard hbase
ENABLE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
ENABLE_WAL_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration name of HLog Compression
enableCatalogJanitor(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Enable/Disable the catalog janitor
enableCatalogJanitor(RpcController, MasterAdminProtos.EnableCatalogJanitorRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
enableCatalogJanitor(RpcController, MasterAdminProtos.EnableCatalogJanitorRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
enableCatalogJanitor(RpcController, MasterAdminProtos.EnableCatalogJanitorRequest, RpcCallback<MasterAdminProtos.EnableCatalogJanitorResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
enableCatalogJanitor(RpcController, MasterAdminProtos.EnableCatalogJanitorRequest, RpcCallback<MasterAdminProtos.EnableCatalogJanitorResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
enableCatalogJanitor(RpcController, MasterAdminProtos.EnableCatalogJanitorRequest, RpcCallback<MasterAdminProtos.EnableCatalogJanitorResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
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_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
 
ENABLED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
 
ENABLED_ZNODE_BYTES - Static variable in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
ZNode content if enabled state.
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.regionserver.wal.HLogPrettyPrinter
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 class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Enable replication to the peer
enableTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Enable a table.
enableTable(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
 
enableTable(RpcController, MasterAdminProtos.EnableTableRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
enableTable(byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Enable an existing table
enableTable(RpcController, MasterAdminProtos.EnableTableRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
enableTable(RpcController, MasterAdminProtos.EnableTableRequest, RpcCallback<MasterAdminProtos.EnableTableResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
enableTable(RpcController, MasterAdminProtos.EnableTableRequest, RpcCallback<MasterAdminProtos.EnableTableResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
enableTable(RpcController, MasterAdminProtos.EnableTableRequest, RpcCallback<MasterAdminProtos.EnableTableResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
enableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
enableTableAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTableAsync(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Brings a table on-line (enables it).
EnableTableHandler - Class in org.apache.hadoop.hbase.master.handler
Handler to run enable of a table.
EnableTableHandler(Server, byte[], CatalogTracker, AssignmentManager, TableLockManager, boolean) - Constructor for class org.apache.hadoop.hbase.master.handler.EnableTableHandler
 
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.regionserver.wal.HLogPrettyPrinter
turns value output on
ENABLING_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
 
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
 
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) - 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_HEADER_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
The size of block header when blockType is BlockType.ENCODED_DATA.
ENCODED_REGION_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.HRegionInfo
A non-capture group so that this can be embedded.
ENCODED_REGION_NAME_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
 
encodeData() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
Do the encoding, but do not cache the encoded data.
EncodedDataBlock - Class in org.apache.hadoop.hbase.io.encoding
Encapsulates a data block compressed using a particular encoding algorithm.
EncodedDataBlock(DataBlockEncoder, boolean, DataBlockEncoding, byte[]) - Constructor for class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
Create a buffer which will be encoded using dataBlockEncoder.
ENCODEDREGIONNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
encodeFileToFile(String, String) - Static method in class org.apache.hadoop.hbase.util.Base64
Reads infile and encodes it to outfile.
encodeFromFile(String) - Static method in class org.apache.hadoop.hbase.util.Base64
Convenience method for reading a binary file and base64-encoding it.
encodeKeyValues(ByteBuffer, boolean, HFileBlockEncodingContext) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
Copied from BufferedDataBlockEncoder.
encodeKeyValues(ByteBuffer, boolean, HFileBlockEncodingContext) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Encodes KeyValues.
encodeObject(Serializable) - Static method in class org.apache.hadoop.hbase.util.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
encodeObject(Serializable, int) - Static method in class org.apache.hadoop.hbase.util.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
encoder - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
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
 
encodeToFile(byte[], String) - Static method in class org.apache.hadoop.hbase.util.Base64
Convenience method for encoding data to a file.
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
 
endDelay(Object) - Method in interface org.apache.hadoop.hbase.ipc.Delayable
Signal that the RPC server is now allowed to send the response.
endDelay() - Method in interface org.apache.hadoop.hbase.ipc.Delayable
Signal the end of a delayed RPC, without specifying the return value.
endDelay(Object) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
endDelay() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
endDelayThrowing(Throwable) - Method in interface org.apache.hadoop.hbase.ipc.Delayable
End the call, throwing and exception to the caller.
endDelayThrowing(Throwable) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
ENDKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
ENDKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
endOffPeakRequest() - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakCompactions
The current compaction finished, so reset the off peak compactions count if this was an off peak compaction.
endOp() - Method in class org.apache.hadoop.hbase.util.DrainBarrier
Ends the operation.
endPersistentOutput() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
ends output of a single, persistent list.
ENDROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
endTime - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
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
 
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
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
 
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_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
entryCount - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Total # of key/value entries, i.e.
ENTRYCOUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
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.regionserver.LruHashMap
Intentionally unimplemented.
entrySet() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
entrySet() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
entryTableSet() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Debugging function that returns a Set of all entries in the hash table.
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_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
 
EQUAL_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
equals(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
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.HConnectionManager.HConnectionKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.Increment
 
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.NullComparator
 
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.hfile.BlockCacheColumnFamilySummary
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
equals(Object) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.ConnectionId
 
equals(Object) - Method in class org.apache.hadoop.hbase.KeyValue
Needed doing 'contains' on List.
equals(Object) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
equals(Object) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
 
equals(Object) - Method in class org.apache.hadoop.hbase.master.RegionPlan
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
equals(Object) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.wal.HLogKey
 
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.ServerName
 
equals(Object) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
 
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.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.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.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.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.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.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 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.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.TScan
 
equals(TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
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.ByteRange
standard methods
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(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.Pair
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.Triple
 
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
 
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
 
ERR_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
 
errorHandler - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
ErrorHandlingProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
ErrorHandlingProtos.ForeignExceptionMessage - Class in org.apache.hadoop.hbase.protobuf.generated
 
ErrorHandlingProtos.ForeignExceptionMessage.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ErrorHandlingProtos.ForeignExceptionMessageOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ErrorHandlingProtos.GenericExceptionMessage - Class in org.apache.hadoop.hbase.protobuf.generated
 
ErrorHandlingProtos.GenericExceptionMessage.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ErrorHandlingProtos.GenericExceptionMessageOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ErrorHandlingProtos.StackTraceElementMessage - Class in org.apache.hadoop.hbase.protobuf.generated
 
ErrorHandlingProtos.StackTraceElementMessage.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ErrorHandlingProtos.StackTraceElementMessageOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ERRORINFO_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
ERRORMESSAGE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
errorMonitor - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotTask
 
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.PayloadCarryingRpcController
 
errorText() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
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 [].
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.
EVENTTYPECODE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
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.DoubleBlockCache
 
evictBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
evictBlock(CachedBlock, 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.SimpleBlockCache
 
evictBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
Evicts the block
evictBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
Evicts a block from the cache.
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.DoubleBlockCache
 
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.SimpleBlockCache
 
evictBlocksByHfileName(String) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
evictBlocksByHfileName(String) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
 
evicted() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
evictedPerEviction() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
ExactCounterMetric - Class in org.apache.hadoop.hbase.metrics
Deprecated. 
ExactCounterMetric(String, MetricsRegistry, String, int) - Constructor for class org.apache.hadoop.hbase.metrics.ExactCounterMetric
Deprecated. Constructor to create a new counter metric
ExactCounterMetric(String, MetricsRegistry) - Constructor for class org.apache.hadoop.hbase.metrics.ExactCounterMetric
Deprecated. Constructor creates a new ExactCounterMetric
ExampleProtos - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
ExampleProtos.CountRequest - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
ExampleProtos.CountRequest.Builder - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
ExampleProtos.CountRequestOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
ExampleProtos.CountResponse - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
ExampleProtos.CountResponse.Builder - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
ExampleProtos.CountResponseOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
ExampleProtos.RowCountService - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
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
 
EXCEPTION_END - Static variable in class org.apache.hadoop.hbase.CompatibilityFactory
 
EXCEPTION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
EXCEPTION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
EXCEPTION_START - Static variable in class org.apache.hadoop.hbase.CompatibilityFactory
 
EXCEPTIONCLASSNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
EXCLUDE_FROM_MINOR_COMPACTION_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Major compaction flag in FileInfo
excludeFromMinorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
exec(String, CancelableProgressable) - Method in interface org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor
 
exec(ExecutorService, String[]) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
EXEC_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
 
execMasterService(RpcController, ClientProtos.CoprocessorServiceRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
execMasterService(RpcController, ClientProtos.CoprocessorServiceRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
execMasterService(RpcController, ClientProtos.CoprocessorServiceRequest, RpcCallback<ClientProtos.CoprocessorServiceResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
execMasterService(RpcController, ClientProtos.CoprocessorServiceRequest, RpcCallback<ClientProtos.CoprocessorServiceResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
execMasterService(RpcController, ClientProtos.CoprocessorServiceRequest, RpcCallback<ClientProtos.CoprocessorServiceResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
execService(RpcController, ClientProtos.CoprocessorServiceRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface
 
execService(RpcController, ClientProtos.CoprocessorServiceRequest, RpcCallback<ClientProtos.CoprocessorServiceResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
execService(RpcController, ClientProtos.CoprocessorServiceRequest, RpcCallback<ClientProtos.CoprocessorServiceResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Interface
 
execService(RpcController, ClientProtos.CoprocessorServiceRequest, RpcCallback<ClientProtos.CoprocessorServiceResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Stub
 
execService(ClientProtocol, ClientProtos.CoprocessorServiceCall, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
execService(MasterAdminProtocol, 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
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.HRegionServer
 
execute(HConnectionManager.HConnectable<T>) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
This convenience method invokes the given HConnectionManager.HConnectable.connect(org.apache.hadoop.hbase.client.HConnection) implementation using a HConnection instance that lasts just for the duration of that invocation.
execute(Server, RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
Run the transaction.
execute(Server, RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransaction
Run the transaction.
execute(Cluster, HttpMethod, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Execute a transaction method.
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.
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.util.HBaseFsck
 
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.
EXISTENCEONLY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
EXISTENCEONLY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
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
Test for the existence of columns in the table, as specified by the Gets.
exists(Get) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Test for the existence of columns in the table, as specified by the Get.
exists(List<Get>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Test for the existence of columns in the table, as specified by the Gets.
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
exists(List) is really a list of get() calls.
exists(ByteBuffer, TGet, AsyncMethodCallback<THBaseService.AsyncClient.exists_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
exists(ByteBuffer, TGet, AsyncMethodCallback<THBaseService.AsyncClient.exists_call>) - 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.
EXISTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
EXISTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
ExistsResource - Class in org.apache.hadoop.hbase.rest
 
ExistsResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.ExistsResource
Constructor
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
 
EXPECTEDTIMEOUT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
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".
expectType(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
expirationDate - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
EXPIRATIONDATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
EXPIRATIONDATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
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
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.ExplicitColumnTracker
Default constructor.
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.exceptions
Thrown when a snapshot could not be exported due to an error during the operation.
ExportSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ExportSnapshotException
 
ExportSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.ExportSnapshotException
 
extendedAttributes - Variable in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
Deprecated. HBase MetricsBase implementations that MetricsDynamicMBeanBase does not understand
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.
extendedInfo - Variable in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
Deprecated.  
extendLimit(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
 
EXTRA_SERIALIZATION_SPACE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
extractArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.CompareFilter
 
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
Deprecated. 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.
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.PayloadCarryingRpcController
 
failed() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
FAILED_CLOSE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
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_OPEN_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
FAILED_OPENING_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
 
FAILED_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
FAILED_SERVER_EXPIRY_DEFAULT - Static variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
FAILED_SERVER_EXPIRY_KEY - Static variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
failedBulkLoad(byte[], String) - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener
Called after a failed HFile load
FailedLogCloseException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when we fail close of the write-ahead-log file.
FailedLogCloseException() - Constructor for exception org.apache.hadoop.hbase.exceptions.FailedLogCloseException
 
FailedLogCloseException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.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
 
failedServers - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
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.
failureSleep - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
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.checkAndPut_args
column family to check
FAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
FAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
FAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
FAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
FAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
FAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
FAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
FAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
FAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
FAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
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
 
familyBuffer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
familyDeduplicator - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
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
 
FAMILYPATH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
FAMILYPATH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
familyRange - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
familyReader - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
FAMILYSCOPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
familySet() - Method in class org.apache.hadoop.hbase.client.Get
Method for retrieving the keys in the familyMap
familyTokenizer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
familyVsQualifier - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
familyVsQualifier - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
 
familyVsQualifier - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
 
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
 
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
 
FEWEST_ITEMS_IN_BUCKET - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
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.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.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.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.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.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.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 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.TPut
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
FILE_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.trace.HBaseLocalFileSpanReceiver
 
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.
FILEINFOOFFSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
FileIOEngine - Class in org.apache.hadoop.hbase.io.hfile.bucket
IO engine that stores data to a file on the local file system.
FileIOEngine(String, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
 
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
 
FILENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
fileSize - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Size of this file.
fileSystemManager - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
 
FileSystemVersionException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when the file system needs to be upgraded
FileSystemVersionException() - Constructor for exception org.apache.hadoop.hbase.exceptions.FileSystemVersionException
default constructor
FileSystemVersionException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.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
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 - 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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
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.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.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
 
filterByLeafAndReverse(ArrayList<TokenizerNode>, boolean) - Static method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
static
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
 
filterIfMissing - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
FILTERIFMISSING_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
filterKeyValue(KeyValue) - 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(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterBase
Filters that dont filter by key value can inherit this implementation that includes all KeyValues.
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
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(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, List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
Constructor that takes a set of Filters and 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
filterOutRow - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
FilterProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ColumnCountGetFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ColumnCountGetFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ColumnCountGetFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ColumnPaginationFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ColumnPaginationFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ColumnPaginationFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ColumnPrefixFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ColumnPrefixFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ColumnPrefixFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ColumnRangeFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ColumnRangeFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ColumnRangeFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.CompareFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.CompareFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.CompareFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.DependentColumnFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.DependentColumnFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.DependentColumnFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FamilyFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FamilyFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FamilyFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FilterList - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FilterList.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FilterList.Operator - Enum in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FilterListOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FilterWrapper - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FilterWrapper.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FilterWrapperOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FirstKeyOnlyFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FirstKeyOnlyFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FirstKeyOnlyFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FirstKeyValueMatchingQualifiersFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FirstKeyValueMatchingQualifiersFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FuzzyRowFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FuzzyRowFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.FuzzyRowFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.InclusiveStopFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.InclusiveStopFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.InclusiveStopFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.KeyOnlyFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.KeyOnlyFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.KeyOnlyFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.MultipleColumnPrefixFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.MultipleColumnPrefixFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.MultipleColumnPrefixFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.PageFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.PageFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.PageFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.PrefixFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.PrefixFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.PrefixFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.QualifierFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.QualifierFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.QualifierFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.RandomRowFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.RandomRowFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.RandomRowFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.RowFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.RowFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.RowFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.SingleColumnValueExcludeFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.SingleColumnValueExcludeFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.SingleColumnValueExcludeFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.SingleColumnValueFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.SingleColumnValueFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.SingleColumnValueFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.SkipFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.SkipFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.SkipFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.TimestampsFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.TimestampsFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.TimestampsFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ValueFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ValueFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.ValueFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.WhileMatchFilter - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.WhileMatchFilter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FilterProtos.WhileMatchFilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.Filter
Chance to alter the list of keyvalues to be submitted.
filterRow() - Method in class org.apache.hadoop.hbase.filter.Filter
Last chance to veto row based on previous Filter.filterKeyValue(KeyValue) calls.
filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.FilterBase
Filters that never filter by modifying the returned List of KeyValues can inherit this implementation that does nothing.
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterBase
Filters that never filter by rows based on previously gathered state from FilterBase.filterKeyValue(KeyValue) can inherit this implementation that never filters a row.
filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
filterRow() - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
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
 
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.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.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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
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
 
find(Object) - Static method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
Look for a RegionMovedException in the exception: - hadoop.ipc wrapped exceptions - nested exceptions Returns null if we didn't find the exception or if it was not readable.
find(Object) - Static method in exception org.apache.hadoop.hbase.exceptions.RegionOpeningException
Look for a RegionOpeningException in the exception: - hadoop.ipc wrapped exceptions - nested exceptions Returns null if we didn't find the exception.
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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.TDeleteType
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.
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
findEntry(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.LRUDictionary
 
findServerWithSameHostnamePort(Collection<ServerName>, ServerName) - Static method in class org.apache.hadoop.hbase.ServerName
 
finish() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
 
finish(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
 
finish(ServerName, String) - Method in interface org.apache.hadoop.hbase.master.SplitLogManager.TaskFinisher
finish the partially done task.
finish() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
 
finishAppend(long, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
 
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.
finishFileInfo() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Add last bits of metadata to file info before it is written out.
finishInitialization(boolean) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
 
finishInitialization() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
Completes the initialization
finishSplitLogFile(String, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
Completes the work done by splitLogFile by archiving logs
finishSplitLogFile(Path, Path, String, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
 
finishSync(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
 
first - Variable in class org.apache.hadoop.hbase.util.Pair
 
first() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
FIRST_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
FIRST_META_REGIONINFO - Static variable in class org.apache.hadoop.hbase.HRegionInfo
HRegionInfo for first meta region
FIRSTDATABLOCKOFFSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
firstInsertionIndex - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
firstKey() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
firstKeyInBlock - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
First key in a block.
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.
FIRSTPART_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
firstRow() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
 
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.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.MemStore
 
FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.ScanInfo
 
FIXED_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
 
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.
fixEmptyMetaCells() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
To fix the empty REGIONINFO_QUALIFIER rows from .META.
fixMetaHoleOnline(Configuration, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
Puts the specified HRegionInfo into META.
fixMultiAssignment(HBaseAdmin, 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(HBaseAdmin, 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.
flush(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Flush a table or an individual region.
flush(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Flush a table or an individual region.
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() - 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.DoubleOutputStream
 
flush() - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
Deprecated.  
flush() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
 
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_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
 
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() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Flush the cache.
flushCache(long, SortedSet<KeyValue>, TimeRangeTracker, AtomicLong, MonitoredTask) - 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
Executes all the buffered Put operations.
flushCommits() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
flushed - Variable in class org.apache.hadoop.hbase.codec.BaseEncoder
 
FLUSHED_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
flushRegion(RpcController, AdminProtos.FlushRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
 
flushRegion(RpcController, AdminProtos.FlushRegionRequest, RpcCallback<AdminProtos.FlushRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
flushRegion(RpcController, AdminProtos.FlushRegionRequest, RpcCallback<AdminProtos.FlushRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
 
flushRegion(RpcController, AdminProtos.FlushRegionRequest, RpcCallback<AdminProtos.FlushRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
flushRegion(RpcController, AdminProtos.FlushRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Flush a region on the region server.
FlushRequester - Interface in org.apache.hadoop.hbase.regionserver
Request a flush.
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<HRegion>, HBaseProtos.SnapshotDescription, RegionServerSnapshotManager.SnapshotSubprocedurePool) - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
 
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
 
FORCE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
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.
FORCIBLE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
FORCIBLE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
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.
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 - 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_VERSION_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
The configuration key for HFile version to use for new files
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.
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
 
freeMemory(long) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Free the requested amount of memory from the LRU map.
FROM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
fromArrays(Collection<byte[]>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeTool
 
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.util.vint.UFIntTool
 
fromBytes(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.vint.UFIntTool
 
fromRowSpec(String, RowSpec, Filter) - Static method in class org.apache.hadoop.hbase.rest.ResultGenerator
 
fromScan(Scan) - Static method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
fs - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
fs - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
fs - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
fs - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
 
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.
fsBlockReader - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Filesystem-level block reader for this HFile format version.
FSHDFSUtils - Class in org.apache.hadoop.hbase.util
Implementation for hdfs
FSHDFSUtils() - Constructor for class org.apache.hadoop.hbase.util.FSHDFSUtils
 
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
 
FSProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
FSProtos.HBaseVersionFileContent - Class in org.apache.hadoop.hbase.protobuf.generated
 
FSProtos.HBaseVersionFileContent.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FSProtos.HBaseVersionFileContentOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FSProtos.Reference - Class in org.apache.hadoop.hbase.protobuf.generated
 
FSProtos.Reference.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
FSProtos.Reference.Range - Enum in org.apache.hadoop.hbase.protobuf.generated
 
FSProtos.ReferenceOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
FSTableDescriptors - Class in org.apache.hadoop.hbase.util
Implementation of TableDescriptors that reads descriptors from the passed filesystem.
FSTableDescriptors(FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.util.FSTableDescriptors
 
FSTableDescriptors(FileSystem, Path, boolean) - Constructor for class org.apache.hadoop.hbase.util.FSTableDescriptors
 
FSTOKEN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
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.DirFilter - Class in org.apache.hadoop.hbase.util
A PathFilter that returns 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.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
 
FSVisitor - Class in org.apache.hadoop.hbase.util
Utility methods for interacting with the hbase.root file system.
FSVisitor.LogFileVisitor - Interface in org.apache.hadoop.hbase.util
 
FSVisitor.RecoveredEditsVisitor - Interface in org.apache.hadoop.hbase.util
 
FSVisitor.StoreFileVisitor - Interface in org.apache.hadoop.hbase.util
 
fullScan(CatalogTracker, Set<String>) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
Performs a full scan of .META., skipping regions from any tables in the specified set of disabled tables.
fullScan(CatalogTracker, Set<String>, boolean) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
Performs a full scan of .META., skipping regions from any tables in the specified set of disabled tables.
fullScan(CatalogTracker) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
Performs a full scan of .META..
fullScan(CatalogTracker, MetaReader.Visitor) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
Performs a full scan of .META..
fullScan(CatalogTracker, MetaReader.Visitor, byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
Performs a full scan of a catalog table.
fullScanMetaAndPrint(CatalogTracker) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
 
fullScanOfMeta(CatalogTracker) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
Performs a full scan of a .META. table.
fullyQualifiedZNode - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
 
FUZZYKEYSDATA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
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
Filters data based on fuzzy row key.
FuzzyRowFilter(List<Pair<byte[], byte[]>>) - Constructor for class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 

G

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.
generateColumnsForCf(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
Generates an applicable set of columns to be used for a particular key and family.
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.
generateRandomSizeValue(byte[]...) - Method in class org.apache.hadoop.hbase.util.test.LoadTestKVGenerator
Generates a value for the given key index and column qualifier.
generateTestKeyValues(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
Generate test data useful to test encoders.
generateToken(String) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
generateValue(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
Generates a value to be used for a particular row/cf/column.
GENERICEXCEPTION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
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) - 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 interface org.apache.hadoop.hbase.client.HTableInterface
Extracts certain cells from a given row.
get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Extracts certain cells from the given rows, in batch.
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() - 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
You should just ignore everything below this line unless there's a bug in Configuration.java...
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.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() - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
Returns the server instance called under or null.
get() - Static method in class org.apache.hadoop.hbase.ipc.RequestContext
 
get() - Static method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
Get singleton instance.
get(RpcController, ClientProtos.GetRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface
 
get(RpcController, ClientProtos.GetRequest, RpcCallback<ClientProtos.GetResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
get(RpcController, ClientProtos.GetRequest, RpcCallback<ClientProtos.GetResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Interface
 
get(RpcController, ClientProtos.GetRequest, RpcCallback<ClientProtos.GetResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Stub
 
get(ClientProtocol, byte[], Get) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to invoke a Get using client protocol.
get(Get) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
get(RpcController, ClientProtos.GetRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Get data from a table.
get(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Retrieves the value associated with the specified key.
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(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(ServletContext, UriInfo) - Method in class org.apache.hadoop.hbase.rest.VersionResource
Build a response for a version request.
get(ZooKeeperWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
get(String) - Method in interface org.apache.hadoop.hbase.TableDescriptors
 
get(byte[]) - Method in interface org.apache.hadoop.hbase.TableDescriptors
 
get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Deprecated. 
get(ByteBuffer, ByteBuffer, byte[], byte[], Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
get(ByteBuffer, TGet, AsyncMethodCallback<THBaseService.AsyncClient.get_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
get(ByteBuffer, TGet, AsyncMethodCallback<THBaseService.AsyncClient.get_call>) - 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 - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
the TGet to check for
get - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
the TGet to fetch
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(int) - Method in class org.apache.hadoop.hbase.util.ByteRange
 
get(byte[]) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
 
get(String) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
 
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(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
GET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
GET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
GET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
GET_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
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
 
getAbsoluteTimestampOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getAbsoluteValueOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
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(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
getAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
getAction(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
 
getAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
getAction(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
 
getAction() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
getActionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getActionBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
getActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
getActionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
 
getActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
getActionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
 
getActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
getActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
getActionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
 
getActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
getActionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
 
getActionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getActionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
getActionOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
 
getActionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getActionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
getActionOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
 
getActions() - Method in class org.apache.hadoop.hbase.security.access.Permission
 
getActiveLogFiles() - Static method in class org.apache.hadoop.hbase.monitoring.LogMonitoring
 
getActiveMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Gets the current active master, if available.
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
 
getAdmin(String, int) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated. - use @link {#getAdmin(final ServerName serverName)} which takes into account the startCode
getAdmin(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Establishes a connection to the region server at the specified address.
getAdmin(String, int, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated. use @link {#getAdmin(final ServerName serverName, boolean getMaster)} which takes into account the startCode.
getAdmin(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Establishes a connection to the region server at the specified address.
getAdmin() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
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
 
getAll() - Method in interface org.apache.hadoop.hbase.TableDescriptors
Get Map of all HTableDescriptors.
getAll() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
 
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
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(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.
getAmount() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
getAny() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
getAny() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
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 FileSystem
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
 
getAssignmentsByTable() - Method in class org.apache.hadoop.hbase.master.RegionStates
This is an EXPENSIVE clone.
getAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
getAssignSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
 
getAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
getAssignSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
 
getAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getAssociatedCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
getAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
getAssociatedCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.Factory
 
getAtomic() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getAtomic() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
getAtomic() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
 
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.metrics.MetricsMBeanBase
Deprecated.  
getAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getAttribute(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getAttribute(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getAttribute(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
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.
getAttributeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getAttributeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getAttributeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getAttributeBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getAttributeBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getAttributeBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getAttributeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getAttributeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getAttributeCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getAttributeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getAttributeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getAttributeCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getAttributeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getAttributeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getAttributeCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getAttributeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getAttributeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getAttributeList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getAttributeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getAttributeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getAttributeList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getAttributeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getAttributeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getAttributeList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getAttributeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getAttributeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getAttributeOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getAttributeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getAttributeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getAttributeOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getAttributeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getAttributeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getAttributeOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getAttributeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getAttributeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getAttributeOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getAttributeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getAttributeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getAttributeOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getAttributeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getAttributeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getAttributeOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getAttributes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getAttributes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getAttributes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
 
getAttributes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getAttributes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getAttributes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getAttributesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getAttributesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getAttributesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getAttributesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getAttributesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getAttributesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getAttributesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
 
getAttributesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getAttributesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getAttributesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getAttributeSize() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
getAttributesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getAttributesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getAttributesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
 
getAttributesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getAttributesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getAttributesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getAttributesMap() - Method in interface org.apache.hadoop.hbase.client.Attributes
Gets all attributes
getAttributesMap() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
getAttributesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getAttributesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getAttributesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
 
getAttributesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getAttributesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getAttributesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getAttributesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getAttributesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getAttributesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
 
getAttributesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getAttributesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getAttributesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getAttrs(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
 
getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getAttrs(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
getAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getAttrsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getAttrsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getAttrsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
 
getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getAttrsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getAttrsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
 
getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getAttrsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getAttrsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
 
getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getAttrsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getAttrsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
 
getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getAttrsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
getAuthenticationToken(RpcController, AuthenticationProtos.TokenRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.BlockingInterface
 
getAuthenticationToken(RpcController, AuthenticationProtos.TokenRequest, RpcCallback<AuthenticationProtos.TokenResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
 
getAuthenticationToken(RpcController, AuthenticationProtos.TokenRequest, RpcCallback<AuthenticationProtos.TokenResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.Interface
 
getAuthenticationToken(RpcController, AuthenticationProtos.TokenRequest, RpcCallback<AuthenticationProtos.TokenResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.Stub
 
getAuthenticationToken(RpcController, AuthenticationProtos.TokenRequest, RpcCallback<AuthenticationProtos.TokenResponse>) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
 
getAuthMethod() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
getAuthMethod() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
getAuthMethod() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponseOrBuilder
 
getAvailablePath(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
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
 
getAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getAverageLoad() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
getAvg(RpcController, AggregateProtos.AggregateArgument, 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.
getAvg(RpcController, AggregateProtos.AggregateArgument) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
 
getAvg(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
getAvg(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
 
getAvg(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
 
getAvgSize() - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
getBackingFs() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
Returns the underlying filesystem
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
getBackupMasters() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getBackupMasters(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getBackupMasters(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getBackupMasters(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getBackupMastersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getBackupMastersBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getBackupMastersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getBackupMastersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getBackupMastersCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getBackupMastersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getBackupMastersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getBackupMastersList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getBackupMastersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getBackupMastersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getBackupMastersOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getBackupMastersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getBackupMastersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getBackupMastersOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
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.TsvImporterMapper
 
getBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getBalancerOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
getBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
getBalancerOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerStateOrBuilder
 
getBalancerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
getBalancerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
getBalancerRan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponseOrBuilder
 
getBaseStagingDir(Configuration) - Static method in class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
 
getBaseZnode() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
getBatch() - Method in class org.apache.hadoop.hbase.client.Scan
 
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
 
getBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getBatch() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
getBatchSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getBatchSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getBatchSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getBigdecimalMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
getBigdecimalMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
getBigdecimalMsg() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsgOrBuilder
 
getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
 
getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
 
getBitwiseOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
getBitwiseOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
getBitwiseOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparatorOrBuilder
 
getBlock(BlockCacheKey, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Fetch block from cache.
getBlock(BlockCacheKey, 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) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
getBlock(BlockCacheKey, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
 
getBlock(BlockCacheKey, 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) - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
getBlock(BlockCacheKey, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
getBlock(BlockCacheKey, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
Get the buffer of the block with the specified name.
getBlockCache() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Returns the block cache.
getBlockCacheColumnFamilySummaries(Configuration) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Performs a BlockCache summary and returns a List of BlockCacheColumnFamilySummary objects.
getBlockCacheColumnFamilySummaries(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getBlockCacheColumnFamilySummaries(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
getBlockCacheColumnFamilySummaries(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
 
getBlockCacheColumnFamilySummaries(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
getBlockCacheColumnFamilySummaries(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
getBlockCacheColumnFamilySummaries(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
getBlockCacheColumnFamilySummaries(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
 
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.
getBlockCacheFreeSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the size of the block cache that is free.
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.
getBlockCacheSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the total size 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.DoubleBlockCache
 
getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
 
getBlockForCaching() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
Creates a new HFileBlock.
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
getBlocks() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
 
getBlocksize() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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 interface org.apache.hadoop.hbase.io.hfile.Cacheable
 
getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockWritable
The type of block this data should use.
getBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getBloomBlockSize(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
 
getBloomFilterType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getBloomFilterType() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
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.CompoundConfiguration
 
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
 
getBuffer() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
getBuffer() - Method in class org.apache.hadoop.hbase.KeyValue
 
getBuffer() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
 
getBufferOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getBufferReadOnly() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Returns the buffer this block stores internally.
getBufferReadOnlyWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Returns the buffer of this block, including header data.
getBufferWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Returns a buffer that does not include the header.
getBulkLoadTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
Return the timestamp at which this bulk load file was generated.
getBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
getBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
getBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequestOrBuilder
 
getBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
getBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
getBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponseOrBuilder
 
getBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
getBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
 
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.ByteRange
 
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(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
 
getByteStream() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
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.protobuf.generated.ClientProtos.Get.Builder
 
getCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getCacheBlocks() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getCacheBlocks() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getCacheConfig() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getCacheConfig() - Method in interface org.apache.hadoop.hbase.regionserver.Store
Used for tests.
getCacheKey() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
 
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
 
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
 
getCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getCaching() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
getCaching() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
getCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
getCall() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
 
getCallBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
getCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
getCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
getCallId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
 
getCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
getCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
getCallId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
 
getCallOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
getCallOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
getCallOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
 
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.
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
 
getCatalogTracker() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getCatalogTracker() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getCatalogTracker() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getCatalogTracker() - Method in interface org.apache.hadoop.hbase.Server
 
getCategory() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
 
getCause(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getCauses() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getCell(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
getCell(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
getCell(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
 
getCellBlockCodecClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
getCellBlockCodecClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
getCellBlockCodecClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
 
getCellBlockCompressorClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
getCellBlockCompressorClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
getCellBlockCompressorClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
 
getCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
getCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
getCellBlockMeta() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
 
getCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
getCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
getCellBlockMeta() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
 
getCellBlockMetaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
getCellBlockMetaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
getCellBlockMetaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
getCellBlockMetaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
getCellBlockMetaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
 
getCellBlockMetaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
getCellBlockMetaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
getCellBlockMetaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
 
getCellBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
getCellBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
getCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
getCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
getCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
 
getCellList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
getCellList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
getCellList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
 
getCellOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
getCellOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
getCellOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
 
getCellOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
getCellOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
getCellOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
 
getCells() - Method in class org.apache.hadoop.hbase.rest.model.RowModel
 
getCellType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
getCellType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
getCellType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellOrBuilder
 
getCellValueFromProto(HBaseProtos.BigDecimalMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
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
getChance() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
getChance() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
getChance() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
getChance() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilterOrBuilder
 
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
 
getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Stub
 
getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
 
getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.Stub
 
getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Stub
 
getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService.Stub
 
getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
 
getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService.Stub
 
getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.Stub
 
getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService.Stub
 
getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Stub
 
getCharset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
getCharset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
getCharset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
 
getCheckAndMutateChecksFailed() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of CAS operations that failed.
getCheckAndMutateChecksPassed() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of CAS operations that passed.
getChecksumFailuresCount() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Number of checksum verification failures.
getChecksumObject() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
returns a object that can be used to generate/validate checksums
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
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.
getClass(String, Class<?>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
getClass(String, Class<? extends U>, Class<U>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
getClassByName(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
getClasses(String, Class<?>...) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
getClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
getClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
getClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
 
getClient(String, int) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated. - use @link {#getClient(final ServerName serverName)} which takes into account the startCode
getClient(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
Establishes a connection to the region server at the specified address, and return a region client protocol.
getClient() - Method in class org.apache.hadoop.hbase.ipc.ProtobufRpcClientEngine
 
getClient() - Method in interface org.apache.hadoop.hbase.ipc.RpcClientEngine
 
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.thrift2.generated.THBaseService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client.Factory
 
getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
getCloseCheckInterval() - Static method in class org.apache.hadoop.hbase.regionserver.HStore
 
getClosed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
getClosed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
getClosed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponseOrBuilder
 
getCloseScanner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
getCloseScanner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
getCloseScanner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
getClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
getClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
getClosestRowBefore() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
 
getClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
getClosestRowBefore() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequestOrBuilder
 
getClosestRowBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
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.client.Mutation
 
getClusterId() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getClusterId() - Method in class org.apache.hadoop.hbase.master.HMaster
 
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.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
getClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
getClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKeyOrBuilder
 
getClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
getClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
getClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterIdOrBuilder
 
getClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getClusterId() - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
 
getClusterId() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the Cluster ID
getClusterId() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
 
getClusterId() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Get the id of the original cluster
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.
getClusterIdBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
getClusterIdBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getClusterIdOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
getClusterIdOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
getClusterIdOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKeyOrBuilder
 
getClusterIdOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getClusterIdOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getClusterIdOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getClusterkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
getClusterkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
getClusterkey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
 
getClusterKey() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
Get the cluster key of that peer
getClusterStatus() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getClusterStatus(RpcController, MasterMonitorProtos.GetClusterStatusRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
getClusterStatus() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getClusterStatus() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
getClusterStatus() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
getClusterStatus() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponseOrBuilder
 
getClusterStatus(RpcController, MasterMonitorProtos.GetClusterStatusRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService.BlockingInterface
 
getClusterStatus(RpcController, MasterMonitorProtos.GetClusterStatusRequest, RpcCallback<MasterMonitorProtos.GetClusterStatusResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService
 
getClusterStatus(RpcController, MasterMonitorProtos.GetClusterStatusRequest, RpcCallback<MasterMonitorProtos.GetClusterStatusResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService.Interface
 
getClusterStatus(RpcController, MasterMonitorProtos.GetClusterStatusRequest, RpcCallback<MasterMonitorProtos.GetClusterStatusResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService.Stub
 
getClusterStatusBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
getClusterStatusOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
getClusterStatusOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
getClusterStatusOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponseOrBuilder
 
getClusterStatusResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
 
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.rest.client.Response
 
getCode() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
 
getColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Return the KeyValues for the specific column.
getColumn(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getColumn(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getColumn(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getColumn(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getColumn(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getColumn(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
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
 
getColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
getColumn() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
 
getColumnBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getColumnBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getColumnBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getColumnBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getColumnCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getColumnCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getColumnCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getColumnCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getColumnCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getColumnCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
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(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getColumnFamilies(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getColumnFamilies(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
getColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
getColumnFamilies() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequestOrBuilder
 
getColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
getColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
getColumnFamilies() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequestOrBuilder
 
getColumnFamilies() - Method in class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
Gets column families for the load test table.
getColumnFamiliesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getColumnFamiliesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
getColumnFamiliesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
getColumnFamiliesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getColumnFamiliesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getColumnFamiliesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getColumnFamiliesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getColumnFamiliesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getColumnFamiliesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getColumnFamiliesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getColumnFamiliesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getColumnFamiliesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getColumnFamiliesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getColumnFamiliesOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
getColumnFamiliesOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
getColumnFamiliesOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequestOrBuilder
 
getColumnFamiliesOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
getColumnFamiliesOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
getColumnFamiliesOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequestOrBuilder
 
getColumnFamiliesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getColumnFamiliesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getColumnFamiliesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getColumnFamily() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
 
getColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
getColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
getColumnFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
 
getColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
getColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
getColumnFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
 
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
 
getColumnHint() - Method in interface org.apache.hadoop.hbase.regionserver.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.ExplicitColumnTracker
 
getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.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
The KeyValue for the most recent timestamp for a given column.
getColumnLatest(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
The KeyValue for the most recent timestamp for a given column.
getColumnLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
 
getColumnList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getColumnList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getColumnList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getColumnList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getColumnList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getColumnList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getColumnName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
getColumnName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
getColumnName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequestOrBuilder
 
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
 
getColumnOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getColumnOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getColumnOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getColumnOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getColumnOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getColumnOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getColumnOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getColumnOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getColumnOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getColumnOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getColumnOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getColumnOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
getColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
getColumnQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
 
getColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
getColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
getColumnQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
 
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
 
getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getColumns(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getColumns(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
getColumns() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
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
 
getColumnsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getColumnsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getColumnsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
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
 
getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getColumnsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getColumnsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
getColumnsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getColumnsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getColumnsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
getColumnsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getColumnsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getColumnsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
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
 
getColumnValue(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getColumnValue(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getColumnValue(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getColumnValueBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getColumnValueBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getColumnValueCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getColumnValueCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getColumnValueCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getColumnValueList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getColumnValueList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getColumnValueList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getColumnValueOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getColumnValueOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getColumnValueOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getColumnValueOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getColumnValueOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getColumnValueOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
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
 
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
 
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
getCompactionRequester() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getCompactionRequester() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getCompactionState(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get the current compaction state of a table or region.
getCompactionState(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get the current compaction state of a table or region.
getCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
getCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
getCompactionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequestOrBuilder
 
getCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
getCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
getCompactionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
 
getCompactionState() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
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
 
getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
getComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparatorOrBuilder
 
getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
getComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparatorOrBuilder
 
getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
getComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparatorOrBuilder
 
getComparableBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
getComparableBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
getComparableBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
getComparableOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparatorOrBuilder
 
getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
getComparableOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparatorOrBuilder
 
getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
getComparableOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparatorOrBuilder
 
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.protobuf.generated.ClientProtos.Condition.Builder
 
getComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
getComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
 
getComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
getComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
getComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilterOrBuilder
 
getComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
getComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
getComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
 
getComparator() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
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.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
 
getComparatorBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
getComparatorBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
getComparatorBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
getComparatorClassName() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getComparatorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getComparatorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getComparatorClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
getComparatorIgnoringTimestamps() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
getComparatorIgnoringType() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
getComparatorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
getComparatorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
getComparatorOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
 
getComparatorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
getComparatorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
getComparatorOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilterOrBuilder
 
getComparatorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
getComparatorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
getComparatorOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
 
getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
getCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
 
getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
getCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilterOrBuilder
 
getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
getCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilterOrBuilder
 
getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
getCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilterOrBuilder
 
getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
getCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilterOrBuilder
 
getCompareFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
getCompareFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
getCompareFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
getCompareFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
getCompareFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
getCompareFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
 
getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
getCompareFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilterOrBuilder
 
getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
getCompareFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilterOrBuilder
 
getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
getCompareFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilterOrBuilder
 
getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
getCompareFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilterOrBuilder
 
getCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
getCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
getCompareOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilterOrBuilder
 
getCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
getCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
getCompareOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
 
getCompareType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
getCompareType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
getCompareType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
 
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, MasterAdminProtos.ListSnapshotRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
List the currently available/stored snapshots.
getCompletedSnapshots() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Gets the list of all completed snapshots.
getCompletedSnapshots(RpcController, MasterAdminProtos.ListSnapshotRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
getCompletedSnapshots(RpcController, MasterAdminProtos.ListSnapshotRequest, RpcCallback<MasterAdminProtos.ListSnapshotResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
getCompletedSnapshots(RpcController, MasterAdminProtos.ListSnapshotRequest, RpcCallback<MasterAdminProtos.ListSnapshotResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
getCompletedSnapshots(RpcController, MasterAdminProtos.ListSnapshotRequest, RpcCallback<MasterAdminProtos.ListSnapshotResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
getCompleteSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getCompleteSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getCompleteSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
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 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 interface org.apache.hadoop.hbase.io.encoding.HFileBlockDecodingContext
 
getCompression() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
 
getCompression() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
getCompression() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
 
getCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getCompression() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
 
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
 
getCompressionCodec() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getCompressionCodec() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getCompressionCodec() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getCompressionCodec() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
getCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getCompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
getCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
getCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
getCondition() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
 
getConditionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
getConditionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
getConditionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
getConditionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
 
getConf() - Method in class org.apache.hadoop.hbase.BaseConfigurable
 
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.tool.Canary
 
getConf() - Method in class org.apache.hadoop.hbase.trace.HBaseLocalFileSpanReceiver
 
getConf() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
getConfiguration() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.HConnection
 
getConfiguration() - Method in class org.apache.hadoop.hbase.client.HTable
Returns the Configuration object used by this instance.
getConfiguration() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
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.master.HMaster
 
getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getConfiguration(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
 
getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getConfiguration(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
Get the configuration object required to communicate with this peer
getConfiguration() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
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
 
getConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getConfigurationBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getConfigurationBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getConfigurationCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
 
getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getConfigurationCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getConfigurationList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
 
getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getConfigurationList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getConfigurationOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
 
getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getConfigurationOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getConfigurationOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
 
getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getConfigurationOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
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
getConnection() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
 
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
Get the connection that goes with the passed conf configuration instance.
getConnection() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. This method will be changed from public to package protected.
getConnection(InetSocketAddress, Class<? extends IpcProtocol>, User, int, HBaseClient.Call, Codec, CompressionCodec) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
 
getConnection(SocketChannel, long) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Subclasses of HBaseServer can override this to provide their own Connection implementations.
getContext(Class<?>) - Method in class org.apache.hadoop.hbase.rest.provider.JAXBContextResolver
 
getCoprocessorHost() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
 
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 class org.apache.hadoop.hbase.master.HMaster
 
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(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getCoprocessors(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getCoprocessors(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getCoprocessors() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getCoprocessors() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the co-processors
getCoprocessorsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getCoprocessorsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getCoprocessorsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getCoprocessorsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getCoprocessorsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getCoprocessorsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getCoprocessorsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getCoprocessorsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getCoprocessorsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getCoprocessorsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getCoprocessorsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getCoprocessorsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getCoprocessorsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getCoprocessorsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getCopyOfOnlineRegionsSortedBySize() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
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
 
getCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
getCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
getCount() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponseOrBuilder
 
getCount() - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
getCountersMapSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getCountersMapSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
getCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
getCreateTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
 
getCreateTime() - Method in class org.apache.hadoop.hbase.RegionTransition
 
getCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
getCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
getCreationTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
 
getCurrent() - Static method in class org.apache.hadoop.hbase.security.User
Returns the User instance within current execution context.
getCurrentCall() - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
Needed for delayed calls.
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
 
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
 
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getCurrentFileSystem(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
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.
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 interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
Get the current log that's replicated
getCurrentPoolSize(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
 
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
Returns the occupied size of the block cache, in bytes.
getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
 
getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the current size of this cache.
getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
 
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.
getData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
getData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
getData() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
 
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.
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.BlockCacheKey
 
getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getDataBlockEncodingId() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getDataBlockEncodingOnDisk() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getDataBlockIndexReader() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getDataBlockIndexReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getDataIndexCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getDataIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getDataIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getDataIndexCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
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.
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.
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.
getDaughterRegions(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Returns the daughter regions by reading the corresponding columns of the catalog table Result.
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
 
getDeadNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getDeadNodes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
getDeadNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getDeadNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getDeadNodesCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
getDeadNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getDeadNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getDeadNodesList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
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
 
getDeadServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getDeadServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
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(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getDeadServers(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getDeadServers(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
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
 
getDeadServersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getDeadServersBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getDeadServersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getDeadServersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getDeadServersCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getDeadServersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getDeadServersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getDeadServersList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getDeadServersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getDeadServersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getDeadServersOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getDeadServersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getDeadServersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getDeadServersOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
getDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
getDeclaringClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
 
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 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.MessageCodec
 
getDecompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
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.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.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.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.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
 
getDefaultValues() - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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!
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
 
getDeleteFamilyCnt() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getDeletes() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
list of TDeletes to delete
getDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
the TDelete to execute if the check succeeds
getDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
the TDelete to delete
getDeletesIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
getDeletesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
getDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
getDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
getDeleteType() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
 
getDeleteType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
getDeleteType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
getDeleteType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
 
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.master.master_jsp
 
getDependants() - Method in class org.apache.hadoop.hbase.generated.master.snapshot_jsp
 
getDependants() - Method in class org.apache.hadoop.hbase.generated.master.table_jsp
 
getDependants() - Method in class org.apache.hadoop.hbase.generated.master.tablesDetailed_jsp
 
getDependants() - Method in class org.apache.hadoop.hbase.generated.master.zk_jsp
 
getDependants() - Method in class org.apache.hadoop.hbase.generated.regionserver.regionserver_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<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 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.protobuf.generated.AccessControlProtos.AccessControlService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.ScopeType
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.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.protobuf.generated.AccessControlProtos.AccessControlService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.ScopeType
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
 
getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
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.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.
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.
getDestinationServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
getDestinationServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
getDestinationServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
 
getDestinationServerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
getDestinationServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
getDestinationServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
getDestinationServerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
 
getDestServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
getDestServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
getDestServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequestOrBuilder
 
getDestServerNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
getDestServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
getDestServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
getDestServerNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequestOrBuilder
 
getDeterministicRandomSeed(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
Creates a deterministic hash code for store file collection.
getDeterministicUniqueKey(long) - Method in class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
Generates a deterministic, unique hashed row key from a number.
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
 
getDisabledOrDisablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTable
Gets a list of all the tables set as disabled in zookeeper.
getDisabledOrDisablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
Gets a list of all the tables set as disabled in zookeeper.
getDisabledTables() - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
Gets a list of all the tables set as disabled in zookeeper.
getDisabledTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTable
Gets a list of all the tables set as disabled in zookeeper.
getDisabledTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
Gets a list of all the tables set as disabled in zookeeper.
getDisablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTable
Gets a list of all the tables set as disabling in zookeeper.
getDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
getDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
getDone() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponseOrBuilder
 
getDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
getDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
getDone() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponseOrBuilder
 
getDoNotRetry() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
getDoNotRetry() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
getDoNotRetry() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
 
getDrainingServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
 
getDropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
getDropDependentColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
getDropDependentColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
getDropDependentColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
 
getEarliestMemstoreSeqNum(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
Gets the earliest sequence number in the memstore for this particular region.
getEdit() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
getEdit() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
getEdit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
 
getEdit() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog.Entry
Gets the edit
getEditBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
getEditOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
getEditOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
getEditOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
 
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.NoOpDataBlockEncoder
 
getEffectiveUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
getEffectiveUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
getEffectiveUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformationOrBuilder
 
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.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.get
 
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.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.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
 
getEnable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
getEnable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
getEnable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequestOrBuilder
 
getEnablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTable
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.
getEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
getEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
getEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKeyOrBuilder
 
getEncodedRegionName() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
 
getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodec
 
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.MessageCodec
 
getEncoder() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Return new data block encoder for given algorithm type.
getEncodingById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
getEncodingCountsForTest() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
getEncodingInCache() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
 
getEncodingInCache() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
getEncodingInCache() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
getEncodingOnDisk() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getEncodingOnDisk() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getEncodingOnDisk() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
 
getEncodingOnDisk() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
getEncodingOnDisk() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
getEnd() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
 
getEndKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getEndKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
getEndKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
getEndKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
 
getEndKey() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
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
 
getEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getEndKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
 
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.HTable
Gets the ending row key for every region in the currently open table.
getEndRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
getEndRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the end row.
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
 
getEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getEndRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
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
 
getEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getEndTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
getEndTime() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
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
 
getEntry(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
getEntry(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
getEntry(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequestOrBuilder
 
getEntry(short) - Method in class org.apache.hadoop.hbase.regionserver.wal.LRUDictionary
 
getEntryBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
getEntryBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
getEntryCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
getEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
getEntryCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequestOrBuilder
 
getEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getEntryCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
getEntryList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
getEntryList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
getEntryList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequestOrBuilder
 
getEntryOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
getEntryOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
getEntryOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequestOrBuilder
 
getEntryOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
getEntryOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
getEntryOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequestOrBuilder
 
getEnvironment() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
 
getErr() - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
 
getErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
getErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
getErrorInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
 
getErrorList() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
getErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
getErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
getErrorMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder
 
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
 
getEventType() - Method in class org.apache.hadoop.hbase.executor.EventHandler
Return the event type
getEventType() - Method in class org.apache.hadoop.hbase.RegionTransition
 
getEventTypeCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
getEventTypeCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
getEventTypeCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
 
getEvictedCount() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Returns the number of evictions that have occurred.
getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
 
getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the number of blocks that have been evicted during the lifetime of this cache.
getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
 
getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the number of eviction runs that have occurred
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.protobuf.generated.ClientProtos.ActionResult.Builder
 
getException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
getException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResultOrBuilder
 
getException() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
getException() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
getException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
 
getException() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTask
 
getException() - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
Get the last exception which has occurred when re-setting the watch.
getExceptionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
getExceptionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
getExceptionClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
getExceptionClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
getExceptionClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
 
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.
getExceptionMsg() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
 
getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
getExceptionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResultOrBuilder
 
getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
getExceptionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
 
getExecutor() - Method in interface org.apache.hadoop.metrics2.MetricsExecutor
 
getExecutorService() - Method in class org.apache.hadoop.hbase.master.HMaster
 
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
 
getExhaustiveDescription() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
getExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
getExistenceOnly() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
 
getExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
getExistenceOnly() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequestOrBuilder
 
getExists() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
getExists() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
getExists() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponseOrBuilder
 
getExists(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
getExists(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
getExists(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponseOrBuilder
 
getExistsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
getExistsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
getExistsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponseOrBuilder
 
getExistsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
getExistsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
getExistsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponseOrBuilder
 
getExistsResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
 
getExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
getExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
getExpectedTimeout() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponseOrBuilder
 
getExpiration() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
 
getExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
getExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
getExpirationDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
 
getExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
getExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
getExpirationDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
 
getExpirationDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
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).
getFailedIncrements() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getFailedIncrements() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
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.
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 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
Primarily for use client-side.
getFamily() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
getFamily(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
 
getFamily(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
getFamily(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
getFamily(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequestOrBuilder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScopeOrBuilder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPathOrBuilder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ColumnOrBuilder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellOrBuilder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValueOrBuilder
 
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.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.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(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
getFamilyArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getFamilyArray() - Method in class org.apache.hadoop.hbase.KeyValue
 
getFamilyCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
getFamilyCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
getFamilyCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequestOrBuilder
 
getFamilyDelimiterIndex(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
 
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
 
getFamilyList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
getFamilyList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
getFamilyList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequestOrBuilder
 
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
Method for retrieving the put's familyMap
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 Mutation.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(int) - Method in class org.apache.hadoop.hbase.KeyValue
 
getFamilyOffsetWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getFamilyPath(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getFamilyPath(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
getFamilyPath(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
 
getFamilyPath(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getFamilyPath(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
getFamilyPath(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
 
getFamilyPathBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getFamilyPathBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getFamilyPathBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getFamilyPathBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getFamilyPathCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getFamilyPathCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
getFamilyPathCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
 
getFamilyPathCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getFamilyPathCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
getFamilyPathCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
 
getFamilyPathList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getFamilyPathList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
getFamilyPathList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
 
getFamilyPathList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getFamilyPathList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
getFamilyPathList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
 
getFamilyPathOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getFamilyPathOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
getFamilyPathOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
 
getFamilyPathOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getFamilyPathOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
getFamilyPathOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
 
getFamilyPathOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getFamilyPathOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
getFamilyPathOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
 
getFamilyPathOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getFamilyPathOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
getFamilyPathOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
 
getFamilyScope(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
getFamilyScope(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
getFamilyScope(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEditOrBuilder
 
getFamilyScopeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
getFamilyScopeBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
getFamilyScopeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
getFamilyScopeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
getFamilyScopeCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEditOrBuilder
 
getFamilyScopeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
getFamilyScopeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
getFamilyScopeList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEditOrBuilder
 
getFamilyScopeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
getFamilyScopeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
getFamilyScopeOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEditOrBuilder
 
getFamilyScopeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
getFamilyScopeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
getFamilyScopeOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEditOrBuilder
 
getFamilySnapshotDirectories(HBaseProtos.SnapshotDescription, Path, FileStatus[]) - Static method in class org.apache.hadoop.hbase.snapshot.TakeSnapshotUtils
Get the snapshot directory for each family to be added to the the snapshot
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
 
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.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.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.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.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.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.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.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.TPut._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
 
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.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.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.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.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.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.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(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(TScan._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getFieldValue(TTimeRange._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
getFileCacheForTesting() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
Exposed for Testing!
getFileDetails(Collection<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
getFileInfoOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getFileInfoOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getFileInfoOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getFileInfoOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
getFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
getFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
getFileName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
 
getFileName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
getFilenum() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
 
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
 
getFilesForScanOrGet(boolean, byte[], byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Gets the store files to scan for a Scan or Get request.
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.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
 
getFilter() - Method in class org.apache.hadoop.hbase.client.Get
 
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.protobuf.generated.ClientProtos.Get.Builder
 
getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
getFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapperOrBuilder
 
getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
getFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilterOrBuilder
 
getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
getFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilterOrBuilder
 
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
 
getFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getFilter() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
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
getFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
getFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
getFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
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.
getFilterIfMissing() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Get whether entire row should be filtered if column is not found.
getFilterIfMissing() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
getFilterIfMissing() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
getFilterIfMissing() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
 
getFilterName(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Returns the filter name given a simple filter expression
getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
getFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapperOrBuilder
 
getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
getFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilterOrBuilder
 
getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
getFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilterOrBuilder
 
getFilters() - Method in class org.apache.hadoop.hbase.filter.FilterList
Get the filters.
getFilters(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
getFilters(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
getFilters(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
 
getFiltersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
getFiltersBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
getFiltersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
getFiltersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
getFiltersCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
 
getFiltersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
getFiltersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
getFiltersList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
 
getFiltersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
getFiltersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
getFiltersOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
 
getFiltersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
getFiltersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
getFiltersOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
 
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() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
getFirst() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
getFirst() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPairOrBuilder
 
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
 
getFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getFirstDataBlockOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
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.Reader
 
getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
 
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(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
 
getFirstPart(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
getFirstPart(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
getFirstPart(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponseOrBuilder
 
getFirstPartCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
getFirstPartCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
getFirstPartCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponseOrBuilder
 
getFirstPartList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
getFirstPartList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
getFirstPartList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponseOrBuilder
 
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
 
getFloat(String, float) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
getFlushed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
getFlushed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
getFlushed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponseOrBuilder
 
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
 
getForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
getForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
getForce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequestOrBuilder
 
getForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
getForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
getForcible() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
 
getForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
getForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
getForcible() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequestOrBuilder
 
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
 
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.DoubleBlockCache
 
getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the current size of this cache.
getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
 
getFrom() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
getFrom() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
getFrom() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRangeOrBuilder
 
getFromOnlineRegions(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
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
getFsToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getFsToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
getFsToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
 
getFsTokenBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getFsTokenOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
getFsTokenOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
getFsTokenOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
 
getFuzzyKeysData(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
getFuzzyKeysData(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
getFuzzyKeysData(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilterOrBuilder
 
getFuzzyKeysDataBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
getFuzzyKeysDataBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
getFuzzyKeysDataCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
getFuzzyKeysDataCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
getFuzzyKeysDataCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilterOrBuilder
 
getFuzzyKeysDataList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
getFuzzyKeysDataList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
getFuzzyKeysDataList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilterOrBuilder
 
getFuzzyKeysDataOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
getFuzzyKeysDataOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
getFuzzyKeysDataOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilterOrBuilder
 
getFuzzyKeysDataOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
getFuzzyKeysDataOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
getFuzzyKeysDataOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilterOrBuilder
 
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.
getGeneralQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
getGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
getGenericException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
 
getGenericExceptionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
getGenericExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
getGenericExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
getGenericExceptionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
 
getGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
getGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
getGet() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
 
getGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
getGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
getGet() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiActionOrBuilder
 
getGet(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getGet(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
getGet(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequestOrBuilder
 
getGet() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
the TGet to check for
getGet() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
the TGet to fetch
getGetBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
getGetBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
getGetBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getGetBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getGetCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getGetCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
getGetCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequestOrBuilder
 
getGetList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getGetList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
getGetList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequestOrBuilder
 
getGetOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
getGetOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
getGetOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
 
getGetOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
getGetOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
getGetOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiActionOrBuilder
 
getGetOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getGetOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
getGetOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequestOrBuilder
 
getGetOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getGetOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
getGetOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequestOrBuilder
 
getGets() - 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
getGetsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
getGetsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
getGlobalMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
 
getGroupName(String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
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.
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.
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
 
getHbaseVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getHbaseVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getHbaseVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getHbaseVersionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getHbaseVersionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getHbaseVersionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getHbaseVersionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
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
This function will return the HDFS blocks distribution based on the data captured when HFile is created
getHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Response
 
getHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Response
 
getHeaderSize() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
getHeaderSize() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
 
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
 
getHeapSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
 
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
 
getHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
getHexDigits(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
getHFileBlock() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
 
getHFileCleaner() - Method in class org.apache.hadoop.hbase.master.HMaster
 
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
getHfileName() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
getHFileNames(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
 
getHFilesChecked() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
 
getHFileVersion() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getHitCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
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.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
 
getHLogDirectoryName(String) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogUtil
Construct the HLog directory name
getHLogNames(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Returns the log file names available in the snapshot.
getHLogRepPosition(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Get the position of the specified hlog in the specified peer znode
getHLogs() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Get a copy of the hlogs of the first source on this rs
getHost() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
 
getHostAddress() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.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.HBaseServer.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.protobuf.generated.HBaseProtos.ServerName.Builder
 
getHostName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
getHostName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
 
getHostname() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
getHostname() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
getHostname() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
 
getHostname() - Method in class org.apache.hadoop.hbase.ServerName
 
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
Returns HRegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result.
getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Returns HRegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result.
getHRegionInfo(Result, byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Returns the HRegionInfo object from the column HConstants.CATALOG_FAMILY and qualifier of the catalog table result.
getHRegionInfo() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
 
getHRegionInfo() - Method in class org.apache.hadoop.hbase.master.handler.MergedRegionHandler
 
getHRegionInfo() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
 
getHRegionInfo() - Method in class org.apache.hadoop.hbase.master.handler.SplitRegionHandler
 
getHRegionInfo() - Method in interface org.apache.hadoop.hbase.master.handler.TotesHRegionInfo
 
getHRegionInfoAndServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Extract a HRegionInfo and ServerName from catalog table Result.
getHTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated. Allows subclasses to get the HTable.
getHTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to get the HTable.
getHTableDescriptor(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
 
getHTableDescriptorArray(MasterMonitorProtos.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
 
getHTableMultiplexerStatus() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
 
getHttpClient() - Method in class org.apache.hadoop.hbase.rest.client.Client
 
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.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
getId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
getId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
 
getId() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
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
 
getId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getId() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
 
getID() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
getId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
getIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
getIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
getIdentifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
 
getIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
getIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
getIdentifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProtoOrBuilder
 
getIdentifier(String, SecretManager<T>) - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
 
getIdentifier() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
getIfOlderThanTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
getIfOlderThanTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
getIfOlderThanTs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
 
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.BackupMasterListTmpl
 
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.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.thrift2.generated.THBaseService.increment_args
the TIncrement to increment
getIndex(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
getIndexStatistics(BucketAllocator.IndexStatistics) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
getIndexStatistics() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
getInfo() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
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.
getInformativeName() - Method in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
 
getInfoServer() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getInfoServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getInfoServerPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getInfoServerPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getInfoServerPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getInfoServerPort() - Method in class org.apache.hadoop.hbase.ServerLoad
 
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
 
getInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getInMemory() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
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.rest.RESTServlet
 
getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
 
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
 
getInt(String, int) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
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
 
getInterpreterClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
getInterpreterClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
getInterpreterClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgumentOrBuilder
 
getInterpreterSpecificBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
getInterpreterSpecificBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
getInterpreterSpecificBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgumentOrBuilder
 
getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_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.get_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.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.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
 
getIOHitsPerSecond() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
 
getIOTimePerHit() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
 
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
 
getIsMasterRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
getIsMasterRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
getIsMasterRunning() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponseOrBuilder
 
getIsolationLevel() - Method in class org.apache.hadoop.hbase.client.Scan
 
getIsShared() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
getIsShared() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
getIsShared() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
 
getIssueDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
getIssueDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
getIssueDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
 
getIssueDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getIterator() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
Provides access to compressed value.
getJar(Class) - Static method in class org.apache.hadoop.hbase.mapreduce.hadoopbackport.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
 
getJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
getJerseyVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
 
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
 
getJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
getJvmVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
 
getKeepAliveMasterAdmin() - Method in interface org.apache.hadoop.hbase.client.HConnection
This function allows HBaseAdmin and potentially others to get a shared MasterAdminProtocol connection.
getKeepAliveMasterMonitor() - Method in interface org.apache.hadoop.hbase.client.HConnection
This function allows HBaseAdminProtocol and potentially others to get a shared MasterMonitor connection.
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.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.protobuf.generated.AdminProtos.WALEntry.Builder
 
getKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
getKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
 
getKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
getKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
getKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
 
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.regionserver.wal.HLog.Entry
Gets the key
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
 
getKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
getKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
 
getKeyBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
getKeyClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogUtil
 
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.
getKeyForNextColumn(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
 
getKeyForNextRow(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
 
getKeyId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
getKeyId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
getKeyId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
 
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.KeyValue
 
getKeyOffset() - Method in class org.apache.hadoop.hbase.KeyValue
 
getKeyOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
getKeyOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
getKeyOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
 
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
 
getKeyType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
getKeyType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
getKeyType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValueOrBuilder
 
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.hfile.HFileReaderV2.EncodedScannerV2
 
getKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
getKeyValue() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
getKeyValueBuffer() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
currently must do deep copy into new array
getKeyValueBuffer() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
 
getKeyValueBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
getKeyValueBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
getKeyValueBytes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEditOrBuilder
 
getKeyValueBytesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
getKeyValueBytesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
getKeyValueBytesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEditOrBuilder
 
getKeyValueBytesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
getKeyValueBytesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
getKeyValueBytesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEditOrBuilder
 
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
 
getKeyValueCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.Interface
 
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.
getKeyValues() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
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.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
getKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
getKind() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
 
getKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
getKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
getKind() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProtoOrBuilder
 
getKind() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
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
 
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
 
getLastContact() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
 
getLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getLastDataBlockOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
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.HMaster
 
getLastFlushedSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
getLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
getLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
getLastFlushedSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponseOrBuilder
 
getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
 
getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest, RpcCallback<RegionServerStatusProtos.GetLastFlushedSequenceIdResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest, RpcCallback<RegionServerStatusProtos.GetLastFlushedSequenceIdResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.Interface
 
getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest, RpcCallback<RegionServerStatusProtos.GetLastFlushedSequenceIdResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.Stub
 
getLastFlushTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
getLastFlushTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
getLastFlushTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponseOrBuilder
 
getLastFlushTime() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
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.Reader
 
getLastRegion() - Method in class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
 
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
 
getLastSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getLastSequenceId(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.LastSequenceId
 
getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Get whether only the latest version of the column value should be compared.
getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
getLatestVersionOnly() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
 
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
 
getLeastSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
getLeastSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
getLeastSigBits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUIDOrBuilder
 
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
 
getLenAsVal() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
getLenAsVal() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
getLenAsVal() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilterOrBuilder
 
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.TableSplit
Deprecated.  
getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the length of the split.
getLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
getLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
getLength() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMetaOrBuilder
 
getLength() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
 
getLength() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Writer
 
getLength() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
 
getLength() - Method in class org.apache.hadoop.hbase.util.ByteRange
 
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.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
getLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
getLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilterOrBuilder
 
getLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
getLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
getLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilterOrBuilder
 
getLimit() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
 
getLimit__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
 
getLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
getLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
getLineNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
 
getListener() - Method in class org.apache.hadoop.hbase.executor.EventHandler
 
getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Return the socket (ip+port) on which the RPC server is listening to.
getListenerAddress() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
 
getListHLogsForPeerForRS(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Get the list of hlogs for the specified region server and peer cluster
getListOfReplicators() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Get the list of the replicators that have queues, they can be alive, dead or simply from a previous run
getListPeersForRS(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Get the list of peer clusters for the specified server names
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
 
getLiveNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getLiveNodes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
getLiveNodesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getLiveNodesBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getLiveNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getLiveNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getLiveNodesCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
getLiveNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getLiveNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getLiveNodesList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
getLiveNodesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getLiveNodesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getLiveNodesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
getLiveNodesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
getLiveNodesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getLiveNodesOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
getLiveRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getLiveServers(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getLiveServers(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getLiveServers(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getLiveServersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getLiveServersBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getLiveServersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getLiveServersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getLiveServersCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getLiveServersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getLiveServersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getLiveServersList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getLiveServersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getLiveServersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getLiveServersOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getLiveServersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getLiveServersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getLiveServersOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
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.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
getLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
getLoad() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
 
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 loadblanacer from the given conf.
getLoadBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
getLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getLoadColumnFamiliesOnDemand() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getLoadColumnFamiliesOnDemandValue() - Method in class org.apache.hadoop.hbase.client.Scan
Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
getLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
getLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
getLoaded() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponseOrBuilder
 
getLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
getLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
getLoaded() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponseOrBuilder
 
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
 
getLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getLoadOnOpenDataOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
getLoadOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
getLoadOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
getLoadOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
 
getLoadSequence() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
 
getLoadSequence() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getLocalFs(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
Wrap a LocalFileSystem within a HFileSystem.
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
 
getLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getLocation() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
 
getLocations() - Method in class org.apache.hadoop.hbase.io.FileLink
 
getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
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(Integer, byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Returns existing row lock if found, otherwise obtains a new row lock and returns it.
getLockEntry(long) - Method in class org.apache.hadoop.hbase.util.IdLock
Blocks until the lock corresponding to the given id is acquired.
getLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
getLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
getLockOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLockOrBuilder
 
getLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
getLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
getLockOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
 
getLockOwnerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
getLockOwnerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
getLockOwnerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
getLockOwnerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
 
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.
getLog() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getLog() - Method in class org.apache.hadoop.hbase.util.MetaUtils
 
getLogDir() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Get the directory where hlogs are stored by their RSs
getLogRoller() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getLogsDir(Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Get log directory for a server in a snapshot.
getLogSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
 
getLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
getLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
getLogSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKeyOrBuilder
 
getLong(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.TimestampDecoder
methods
getLong(String, long) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
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
 
getLongMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
getLongMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
getLongMsg() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsgOrBuilder
 
getLowestTimestamp(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
Gets lowest timestamp from candidate StoreFiles
getMajor() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
getMajor() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
getMajor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
 
getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
Returns the major version of this HFile format
getMap() - Method in class org.apache.hadoop.hbase.client.Result
Map of families to all versions of its qualifiers and values.
getMapEntries(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
getMapEntries(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
getMapEntries(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponseOrBuilder
 
getMapEntriesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
getMapEntriesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
getMapEntriesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
getMapEntriesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
getMapEntriesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponseOrBuilder
 
getMapEntriesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
getMapEntriesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
getMapEntriesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponseOrBuilder
 
getMapEntriesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
getMapEntriesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
getMapEntriesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponseOrBuilder
 
getMapEntriesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
getMapEntriesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
getMapEntriesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponseOrBuilder
 
getMapEntry(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
getMapEntry(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
getMapEntry(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProtoOrBuilder
 
getMapEntryBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
getMapEntryBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
getMapEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
getMapEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
getMapEntryCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProtoOrBuilder
 
getMapEntryList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
getMapEntryList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
getMapEntryList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProtoOrBuilder
 
getMapEntryOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
getMapEntryOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
getMapEntryOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProtoOrBuilder
 
getMapEntryOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
getMapEntryOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
getMapEntryOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProtoOrBuilder
 
getMapperClass(JobContext) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
Get the application's mapper class.
getMaster() - Method in class org.apache.hadoop.hbase.ClusterStatus
Returns detailed information about the current master ServerName.
getMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getMaster() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
getMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
getMaster() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MasterOrBuilder
 
getMaster() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterListTmpl.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.
getMasterAddressManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getMasterAddressZNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
getMasterAdmin() - Method in interface org.apache.hadoop.hbase.client.HConnection
Returns a MasterAdminProtocol to the active master
getMasterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getMasterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getMasterCoprocessors(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getMasterCoprocessors(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getMasterCoprocessors(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getMasterCoprocessorsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getMasterCoprocessorsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getMasterCoprocessorsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getMasterCoprocessorsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getMasterCoprocessorsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getMasterCoprocessorsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getMasterCoprocessorsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getMasterCoprocessorsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getMasterCoprocessorsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getMasterCoprocessorsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getMasterCoprocessorsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getMasterCoprocessorsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getMasterCoprocessorsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getMasterCoprocessorsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getMasterFileSystem() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMasterFileSystem() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getMasterMonitor() - Method in interface org.apache.hadoop.hbase.client.HConnection
Returns an MasterMonitorProtocol to the active master
getMasterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getMasterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getMasterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getMasterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
getMasterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
getMasterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MasterOrBuilder
 
getMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
getMasterServices() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
 
getMasterStartTime() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getMasterTimerAndBindToMonitor(HBaseProtos.SnapshotDescription, Configuration, ForeignExceptionListener) - Static method in class org.apache.hadoop.hbase.snapshot.TakeSnapshotUtils
Create a snapshot timer for the master which notifies the monitor when an error occurs
getMatchingNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
 
getMax(RpcController, AggregateProtos.AggregateArgument, 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.TimeRange
 
getMax() - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
getMax(RpcController, AggregateProtos.AggregateArgument) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
 
getMax(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
getMax(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
 
getMax(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
 
getMaxAllowedOperationTime() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
 
getMaxChunkSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
 
getMaxColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMaxColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
getMaxColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
getMaxColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
 
getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
getMaxColumnInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
 
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.
getMaxFold(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
 
getMaxHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getMaxHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getMaxHeapMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
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
 
getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getMaxHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
getMaximumAllocationIndex() - Static method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
getMaximumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
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
 
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
 
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
 
getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.Scan
 
getMaxResultSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getMaxResultSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getMaxResultSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
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
 
getMaxRetries() - Method in class org.apache.hadoop.hbase.util.RetryCounter
 
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.StoreFile
 
getMaxSequenceIdInList(Collection<StoreFile>, boolean) - 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 class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the maximum size of this cache.
getMaxStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
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.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.protobuf.generated.ClientProtos.Get.Builder
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getMaxVersions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getMaxVersions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
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
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getMBeanInfo() - Method in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
Deprecated.  
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.metrics.histogram.MetricsHistogram
Deprecated.  
getMechanismName() - Method in enum org.apache.hadoop.hbase.security.AuthMethod
Return the SASL mechanism name
getMedian(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
Gives a List containing sum of values and sum of weights.
getMedian(RpcController, AggregateProtos.AggregateArgument) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
 
getMedian(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
getMedian(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
 
getMedian(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
 
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
 
getMemberName() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
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
Gets the Memstore flush size for the region that this store works with.
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.Store
 
getMemstoreSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
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
 
getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
getMemstoreTS() - Method in class org.apache.hadoop.hbase.KeyValue
Deprecated. 
getMemUsed() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Get the currently used memory for this LRU in bytes.
getMergedRegionInfo(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
Get merged region info through the specified two regions
getMessage() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
getMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
getMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
 
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
 
getMetaIndexCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getMetaIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getMetaIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getMetaIndexCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
getMetaLocation() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
Gets the current location for .META. or null if location is not currently available.
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
 
getMetaRegion() - Method in class org.apache.hadoop.hbase.util.MetaUtils
 
getMetaRegionLocation() - Method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
Gets the meta region location, if available.
getMetaRegionLocation(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
Gets the meta region location, if available.
getMetaWALActionListeners() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
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
 
getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
getMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
 
getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
getMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
 
getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
getMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
 
getMetrics() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Returns the metrics instance for reporting RPC call statistics
getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
getMetrics() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
Returns the metrics instance for reporting RPC call statistics
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(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
getMetrics(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
getMetrics(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetricsOrBuilder
 
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.
getMetricsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
getMetricsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
getMetricsContext() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Get the metrics context.
getMetricsContext() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
getMetricsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
getMetricsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
getMetricsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetricsOrBuilder
 
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
 
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
 
getMetricsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
getMetricsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
getMetricsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetricsOrBuilder
 
getMetricsMap() - Method in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
Get all of the values since the last time this function was called.
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
 
getMetricsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
getMetricsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
getMetricsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetricsOrBuilder
 
getMetricsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
getMetricsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
getMetricsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetricsOrBuilder
 
getMetricsRegistry() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
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
 
getMin() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
get/set
getMin(RpcController, AggregateProtos.AggregateArgument, 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.TimeRange
 
getMin() - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
getMin(RpcController, AggregateProtos.AggregateArgument) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
 
getMin(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
getMin(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
 
getMin(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
 
getMinColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMinColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
getMinColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
getMinColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
 
getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
getMinColumnInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
 
getMinimumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
getMinimumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
getMinMvccVersion() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getMinStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
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.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
 
getMissCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
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.regionserver.LruHashMap
Get the number of misses to the map.
getMissing() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
 
getMissRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
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
 
getMoreResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getMoreResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
getMoreResults() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
 
getMostLoadedRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Get the top N most loaded regions this server is serving so we can tell the master which regions it can reallocate if we're overloaded.
getMostSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
getMostSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
getMostSigBits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUIDOrBuilder
 
getMultiple(ByteBuffer, List<TGet>, AsyncMethodCallback<THBaseService.AsyncClient.getMultiple_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
getMultiple(ByteBuffer, List<TGet>, AsyncMethodCallback<THBaseService.AsyncClient.getMultiple_call>) - 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) - Method in class org.apache.hadoop.hbase.rest.TableResource
 
getMutateType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getMutateType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getMutateType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
getMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
getMutation() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiActionOrBuilder
 
getMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
getMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
getMutation() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
 
getMutationBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
getMutationBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
getMutationOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
getMutationOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
getMutationOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiActionOrBuilder
 
getMutationOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
getMutationOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
getMutationOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
 
getMutationRequest(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
getMutationRequest(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
getMutationRequest(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequestOrBuilder
 
getMutationRequestBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
getMutationRequestBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
getMutationRequestCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
getMutationRequestCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
getMutationRequestCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequestOrBuilder
 
getMutationRequestList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
getMutationRequestList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
getMutationRequestList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequestOrBuilder
 
getMutationRequestOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
getMutationRequestOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
getMutationRequestOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequestOrBuilder
 
getMutationRequestOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
getMutationRequestOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
getMutationRequestOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequestOrBuilder
 
getMutations() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
getMVCC() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getMvccReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
 
getMvccVersion() - Method in interface org.apache.hadoop.hbase.Cell
Internal use only.
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
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 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
Get the name of the table as a byte array.
getName() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
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.procedure.Procedure
 
getName() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ComparatorOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CoprocessorOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FilterOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPairOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64PairOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPairOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
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.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
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
 
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
 
getName(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
getName(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
getName(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
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 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
 
getNameCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
getNameCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
getNameCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
 
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.
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
 
getNameList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
 
getNameList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
 
getNegativeIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getNewByteArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
writing back to byte[]'s
getNextBlockOnDiskSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getNextCallSeq() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
getNextCallSeq() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
getNextCallSeq() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
getNextIndexedKey() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
 
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
getNextKeyHint(KeyValue) - 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.
getNextKeyHint(KeyValue) - 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 KeyValue.
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
 
getNextMajorCompactTime(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactionPolicy
 
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
 
getNextPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
Poll for the next path
getNextPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns the next pointer for the entry in teh LRU.
getNextRowOrNextColumn(byte[], int, int) - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
Retrieve the MatchCode for the next row or column
getNextRowOrNextColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
 
getNextRowOrNextColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
 
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
 
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
 
getNoVersionMap() - Method in class org.apache.hadoop.hbase.client.Result
Map of families to their most recent qualifiers and values.
getNumAdded() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
read
getNumber() - Method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.ScopeType
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
 
getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
 
getNumberOfChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Get the number of children of the specified node.
getNumberOfOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getNumberOfRegions() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getNumberOfRequests() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getNumberOfRows() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
getNumberOfRows() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
getNumberOfRows() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
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
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
 
getNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getNumDataIndexLevels() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
getNumExceptions() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
getNumFamilyBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
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
 
getNumMetaBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumMvccVersionBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumNubNodesIncludingThisNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getNumOccurrences() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
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
 
getNumPutsWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Number of mutations received with WAL explicitly turned off.
getNumQualifierBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getNumQueriesForTesting(int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
 
getNumRegions() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
 
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.getScannerRows_args
number of rows to return
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
 
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
 
getNumUniqueValues() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
getNumValueBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
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.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.
getOccupiedSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
getOffline() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
getOffline() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
getOffline() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
 
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.HFileBlock
 
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.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
getOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
getOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilterOrBuilder
 
getOffset() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
 
getOffset() - Method in class org.apache.hadoop.hbase.util.ByteRange
 
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 hlogs are archived
getOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
getOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
getOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequestOrBuilder
 
getOnDiskBytesWithHeader() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
getOnDiskBytesWithHeader() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
 
getOnDiskSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getOnDiskSizeWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Returns the size of the compressed part of the block in case compression is used, or the uncompressed size of the data part otherwise.
getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
 
getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest, RpcCallback<AdminProtos.GetOnlineRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest, RpcCallback<AdminProtos.GetOnlineRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
 
getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest, RpcCallback<AdminProtos.GetOnlineRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
getOnlineRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getOnlineRegions(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Get all the online regions on a region server.
getOnlineRegions(AdminProtocol) - 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(byte[]) - 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.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
 
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.
getOpenInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
getOpenInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
getOpenInfo(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
 
getOpenInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
getOpenInfoBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
getOpenInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
getOpenInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
getOpenInfoCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
 
getOpenInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
getOpenInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
getOpenInfoList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
 
getOpenInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
getOpenInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
getOpenInfoOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
 
getOpenInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
getOpenInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
getOpenInfoOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
 
getOpeningState(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
getOpeningState(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
getOpeningState(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponseOrBuilder
 
getOpeningStateCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
getOpeningStateCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
getOpeningStateCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponseOrBuilder
 
getOpeningStateList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
getOpeningStateList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
getOpeningStateList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponseOrBuilder
 
getOpenSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Gets the latest sequence number that was read from storage when this region was opened.
getOperation(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 class org.apache.hadoop.hbase.client.HTable
 
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.protobuf.generated.FilterProtos.FilterList.Builder
 
getOperator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
getOperator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
 
getOriginalIndex() - Method in class org.apache.hadoop.hbase.client.Action
 
getOriginPath() - Method in class org.apache.hadoop.hbase.io.HFileLink
 
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
 
getOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
getOsVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
 
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.
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.
getOutputStreamForEncoder() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
getOutputStreamForEncoder() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
 
getOverlapGroups(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
getOwnerString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated. 
getPaddedTokenAndOccurrenceString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
getPageSize() - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
getPageSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
getPageSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
getPageSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilterOrBuilder
 
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.protobuf.generated.Tracing.RPCTInfo.Builder
 
getParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
getParentId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfoOrBuilder
 
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.
getPartition(ImmutableBytesWritable, V2, int) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
Deprecated.  
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(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
getPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
getPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
getPassword() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
 
getPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
getPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
getPassword() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProtoOrBuilder
 
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.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
getPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
getPath() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPathOrBuilder
 
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
 
getPattern() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
getPattern() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
getPattern() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
 
getPatternFlags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
getPatternFlags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
getPatternFlags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
 
getPauseTime(long, int) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
Calculate pause time.
getPayload() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
getPayload() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
getPayload() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
 
getPayload() - Method in class org.apache.hadoop.hbase.RegionTransition
 
getPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Helper method to connect to a peer
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.
getPeerClusters() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Get a map of all peer clusters
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
getPeerEnabled() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
Get the state of this peer
getPeerEnabled(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Check whether the peer is enabled or not.
getPeersCount() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the number of slave clusters the local cluster has.
getPeersZNode() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Get the full path to the peers' znode
getPeerUUID(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Returns the UUID of the provided peer id.
getPercentFileLocal() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the percent of HFiles' that are local.
getPermission(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
getPermission(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
getPermission(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequestOrBuilder
 
getPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
getPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
getPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequestOrBuilder
 
getPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
getPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
getPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequestOrBuilder
 
getPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
getPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
getPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionOrBuilder
 
getPermission(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
getPermission(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
getPermission(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponseOrBuilder
 
getPermissionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
getPermissionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
getPermissionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
getPermissionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
getPermissionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
getPermissionBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
getPermissionBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
getPermissionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
getPermissionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
getPermissionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequestOrBuilder
 
getPermissionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
getPermissionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
getPermissionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponseOrBuilder
 
getPermissionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
getPermissionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
getPermissionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequestOrBuilder
 
getPermissionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
getPermissionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
getPermissionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponseOrBuilder
 
getPermissionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
getPermissionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
getPermissionOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequestOrBuilder
 
getPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
getPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
getPermissionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequestOrBuilder
 
getPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
getPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
getPermissionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequestOrBuilder
 
getPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
getPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
getPermissionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionOrBuilder
 
getPermissionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
getPermissionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
getPermissionOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponseOrBuilder
 
getPermissionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
getPermissionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
getPermissionOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequestOrBuilder
 
getPermissionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
getPermissionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
getPermissionOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponseOrBuilder
 
getPermissions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
getPermissions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
getPermissions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
getPermissions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
getPermissions(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissionsOrBuilder
 
getPermissions(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissionsOrBuilder
 
getPermissionsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
getPermissionsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
getPermissionsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
getPermissionsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
getPermissionsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
getPermissionsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
getPermissionsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
getPermissionsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
getPermissionsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissionsOrBuilder
 
getPermissionsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissionsOrBuilder
 
getPermissionsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
getPermissionsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
getPermissionsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
getPermissionsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
getPermissionsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissionsOrBuilder
 
getPermissionsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissionsOrBuilder
 
getPermissionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
getPermissionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
getPermissionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
getPermissionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
getPermissionsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissionsOrBuilder
 
getPermissionsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissionsOrBuilder
 
getPermissionsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
getPermissionsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
getPermissionsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
getPermissionsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
getPermissionsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissionsOrBuilder
 
getPermissionsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissionsOrBuilder
 
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
 
getPoolSize(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.HBaseClient
Return the pool size specified in the configuration, which is applicable only if the pool type is PoolMap.PoolType.RoundRobin.
getPoolTaskCount() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getPoolTaskCount() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getPoolType(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.HBaseClient
Return the pool type specified in the configuration, which must be set to either PoolMap.PoolType.RoundRobin or PoolMap.PoolType.ThreadLocal, otherwise default to the former.
getPort() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getPort() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
getPort() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
 
getPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
getPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
getPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
 
getPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
getPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
getPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
 
getPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
getPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
getPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
 
getPort() - Method in class org.apache.hadoop.hbase.ServerName
 
getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
getPosition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
getPosition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
getPosition() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPositionOrBuilder
 
getPosition() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Reader
 
getPosition() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
getPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
Get the position that we stopped reading at
getPreadLatenciesNanos() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
getPreadOps() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
getPreadTimeMs() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
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
 
getPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
getPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
getPrefix() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilterOrBuilder
 
getPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
getPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
getPrefix() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilterOrBuilder
 
getPrevBalanceValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
getPrevBalanceValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
getPrevBalanceValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponseOrBuilder
 
getPrevBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getPreviousIntervalValue() - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
Deprecated.  
getPrevPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns the previous pointer for the entry in the LRU.
getPrevValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
getPrevValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
getPrevValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponseOrBuilder
 
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.io.hfile.CachedBlock
 
getPriority() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
 
getPriority() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
 
getPriority() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
Gets the priority for the request
getPriorityQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getProcedure(String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
Returns the procedure.
getProcedureNames() - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
 
getProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
getProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
getProcessed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponseOrBuilder
 
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.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.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
getProtocol() - Method in exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
 
getProtocol() - Method in class org.apache.hadoop.hbase.ipc.RequestContext
 
getProtocol() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
getProtocol() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
getProtocol() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
 
getProtoForCellType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
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(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
getProxy(Class<T>, InetSocketAddress, Configuration, int) - Method in class org.apache.hadoop.hbase.ipc.ProtobufRpcClientEngine
 
getProxy(Class<T>, InetSocketAddress, Configuration, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcClientEngine
Construct a client-side proxy object.
getPurpose() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
getPurpose() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
getPurpose() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
 
getPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
the TPut to put if the check succeeds
getPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
the TPut to put
getPuts() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
a list of TPuts to commit
getPutsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
getPutsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
getQosLevel(Pair<RPCProtos.RequestHeader, Message>) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
 
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
Primarily for use client-side.
getQualifier() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
getQualifier(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
getQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
 
getQualifier(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
getQualifier(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
getQualifier(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ColumnOrBuilder
 
getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
getQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
 
getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
getQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
 
getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
getQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellOrBuilder
 
getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
getQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValueOrBuilder
 
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.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.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(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
getQualifierArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getQualifierArray() - Method in class org.apache.hadoop.hbase.KeyValue
 
getQualifierBufferLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
getQualifierCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
getQualifierCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
getQualifierCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ColumnOrBuilder
 
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(int, int) - Method in class org.apache.hadoop.hbase.KeyValue
 
getQualifierList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
getQualifierList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
getQualifierList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ColumnOrBuilder
 
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(int) - Method in class org.apache.hadoop.hbase.KeyValue
 
getQualifierOffsetWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getQualifiers(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
getQualifiers(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
getQualifiers(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilterOrBuilder
 
getQualifiersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
getQualifiersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
getQualifiersCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilterOrBuilder
 
getQualifiersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
getQualifiersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
getQualifiersList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilterOrBuilder
 
getQualifierSorter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getQualifierString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
getQualifierValue(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
getQualifierValue(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
getQualifierValue(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
 
getQualifierValueBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
getQualifierValueBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
getQualifierValueCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
getQualifierValueCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
getQualifierValueCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
 
getQualifierValueList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
getQualifierValueList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
getQualifierValueList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
 
getQualifierValueOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
getQualifierValueOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
getQualifierValueOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
 
getQualifierValueOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
getQualifierValueOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
getQualifierValueOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
 
getQualifierWriter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getQuarantined() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
 
getQueueSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
getQueueSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
getQuorum() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Get the quorum address of this instance.
getRange(String, String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
getRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
getRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
getRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.ReferenceOrBuilder
 
getRaw(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
getRawComparator() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
getRawComparator() - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
 
getRawComparator() - Method in class org.apache.hadoop.hbase.KeyValue.RootComparator
 
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.
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(FileSystem, FileStatus, Configuration, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
Create a new HLog.Reader for reading logs to split.
getReader(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
Create a new HLog.Reader for reading logs to split.
getReader() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
 
getReadLatenciesNanos() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
getReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
getReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
getReadOnly() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
getReadOps() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
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
 
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of read requests to regions hosted on this region server.
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
 
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
getReadRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getReadTimeMs() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
getRealUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
getRealUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
getRealUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformationOrBuilder
 
getReason() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
getReason() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
getReason() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequestOrBuilder
 
getReason() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated. Builds a TableRecordReader.
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
Deprecated.  
getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
 
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.
getRecoveredEdits(Path, String, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Get the snapshot recovered.edits file
getRecoveredEditsDir(Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Get the snapshotted recovered.edits dir for the specified region.
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
getReferredToFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
getRegion(CatalogTracker, byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
Gets the region info and assignment for the specified region.
getRegion() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
 
getRegion() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequestOrBuilder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequestOrBuilder
 
getRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Protected utility method for safely obtaining an HRegion handle.
getRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Find the HRegion based on a region specifier
getRegion(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
getRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
getRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
getRegionA() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
 
getRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
getRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
getRegionA() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequestOrBuilder
 
getRegionABuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
getRegionABuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
getRegionAOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
getRegionAOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
getRegionAOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
 
getRegionAOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
getRegionAOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
getRegionAOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequestOrBuilder
 
getRegionArchiveDir(Path, 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, Path, Path) - 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
 
getRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
getRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
getRegionB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
 
getRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
getRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
getRegionB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequestOrBuilder
 
getRegionBBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
getRegionBBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
getRegionBOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
getRegionBOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
getRegionBOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
 
getRegionBOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
getRegionBOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
getRegionBOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequestOrBuilder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
getRegionByEncodedName(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRegionCachePrefetch(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Check whether region cache prefetch is enabled or not.
getRegionCachePrefetch(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
Check whether region cache prefetch is enabled or not for the table.
getRegionCachePrefetch(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
Check whether region cache prefetch is enabled or not for the table.
getRegionCount(Configuration, String) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
Count regions in .META. for passed table.
getRegionDir(Path, String) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Deprecated. 
getRegionDir(Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Deprecated. 
getRegionDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
 
getRegionDirRecoveredEditsDir(Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogUtil
 
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
getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getRegionHFileReferences(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Get the list of hfiles for the specified snapshot region.
getRegionId() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
getRegionId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
getRegionId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
 
getRegionId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
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 META table
getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
 
getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest, RpcCallback<AdminProtos.GetRegionInfoResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest, RpcCallback<AdminProtos.GetRegionInfoResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
 
getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest, RpcCallback<AdminProtos.GetRegionInfoResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
getRegionInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
getRegionInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
getRegionInfo(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponseOrBuilder
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
getRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
getRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
 
getRegionInfo(AdminProtocol, 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(RpcController, AdminProtos.GetRegionInfoRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
 
getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getRegionInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getRegionInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
getRegionInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
getRegionInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
getRegionInfoBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
getRegionInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
getRegionInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
getRegionInfoCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponseOrBuilder
 
getRegionInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
getRegionInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
getRegionInfoList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponseOrBuilder
 
getRegionInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
getRegionInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
getRegionInfoOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponseOrBuilder
 
getRegionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
getRegionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
getRegionInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
 
getRegionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
getRegionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
getRegionInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
 
getRegionInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
getRegionInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
getRegionInfoOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponseOrBuilder
 
getRegionInfos(AdminProtos.GetOnlineRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the list of region info from a GetOnlineRegionResponse
getRegionLoads(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getRegionLoads(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getRegionLoads(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getRegionLoadsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getRegionLoadsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getRegionLoadsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getRegionLoadsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getRegionLoadsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getRegionLoadsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getRegionLoadsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getRegionLoadsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getRegionLoadsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getRegionLoadsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getRegionLoadsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getRegionLoadsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getRegionLoadsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getRegionLoadsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getRegionLocation(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Find region location hosting passed row
getRegionLocation(String) - Method in class org.apache.hadoop.hbase.client.HTable
Find region location hosting passed row using cached info
getRegionLocation(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Finds the region on which the given row is being served.
getRegionLocation(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Finds the region on which the given row is being served.
getRegionLocation() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
getRegionLocation() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the region location.
getRegionLocations() - Method in class org.apache.hadoop.hbase.client.HTable
Gets all the regions and their address for this table.
getRegionName() - Method in class org.apache.hadoop.hbase.client.ServerCallable
Deprecated. Just use Object.toString() instead.
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 class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
getRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
getRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequestOrBuilder
 
getRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
getRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
getRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
 
getRegionName() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
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() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
getRegionNameAsString() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getRegionNameAsString() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
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
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequestOrBuilder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequestOrBuilder
 
getRegionReopenPlan(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
getRegionResult(CatalogTracker, byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
Gets the result in META for the specified region.
getRegions() - Method in class org.apache.hadoop.hbase.client.MultiAction
 
getRegions(AdminProtos.RollWALWriterResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the list of regions to flush from a RollLogWriterResponse
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
 
getRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getRegions(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
getRegions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
getRegions(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
 
getRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getRegionsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getRegionsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getRegionsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getRegionsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
getRegionsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
 
getRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
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
 
getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
Return the RegionServer-level coprocessors
getRegionServerFatalLogBuffer() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getRegionServerOfRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
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.ReplicationPeer
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.
getRegionServerWithoutRetries(ServerCallable<T>) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated. 
getRegionServerWithRetries(ServerCallable<T>) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated. 
getRegionServerWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
getRegionsFromMergeQualifier(CatalogTracker, byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
Get regions from the merge qualifier of the specified merged region
getRegionsInRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Get the corresponding regions for an arbitrary range of keys.
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
getRegionsInTransition(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getRegionsInTransition(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getRegionsInTransition(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getRegionsInTransitionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getRegionsInTransitionBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getRegionsInTransitionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getRegionsInTransitionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getRegionsInTransitionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
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
getRegionsInTransitionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getRegionsInTransitionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getRegionsInTransitionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getRegionsInTransitionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getRegionsInTransitionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getRegionsInTransitionOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getRegionsInTransitionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
getRegionsInTransitionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getRegionsInTransitionOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getRegionsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
getRegionsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
 
getRegionsLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getRegionSnapshotDirectory(HBaseProtos.SnapshotDescription, Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.TakeSnapshotUtils
Get the per-region snapshot description location.
getRegionsOfTable(byte[]) - 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
 
getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getRegionsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
getRegionsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
 
getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getRegionsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
getRegionsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
 
getRegionSpecifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getRegionSpecifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getRegionSpecifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
getRegionSpecifierBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getRegionSpecifierOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getRegionSpecifierOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getRegionSpecifierOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
getRegionSplitLimit() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
getRegionSplitPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
This get 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
 
getRegionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
getRegionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
getRegionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
 
getRegionStateBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
getRegionStateOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
getRegionStateOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
getRegionStateOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
 
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.
getRegionToFlush(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
getRegionToFlush(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
getRegionToFlush(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponseOrBuilder
 
getRegionToFlushCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
getRegionToFlushCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
getRegionToFlushCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponseOrBuilder
 
getRegionToFlushList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
getRegionToFlushList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
getRegionToFlushList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponseOrBuilder
 
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
getRegisteredRegionServers() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Get a list of all the other region servers in this cluster and set a watch
getRemoteAddress() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
getRemoteAddress() - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
Returns remote address as a string when invoked inside an RPC.
getRemoteAddress() - Method in class org.apache.hadoop.hbase.ipc.RequestContext
 
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.HBaseServer
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.HBaseServer.Connection
 
getReopenStatus(byte[]) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Used by the client to identify if all regions have the schema updates
getReplicating() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Get the current status of the kill switch, if the cluster is replicating or not.
getReplication() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Get the replication status of this cluster.
getReplicationManager() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
Get the replication sources manager
getReplicationQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
getReplicationSource(Configuration, FileSystem, ReplicationSourceManager, Stoppable, AtomicBoolean, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Factory method to create a replication source
getReportEndTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getReportEndTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getReportEndTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getReportStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getReportStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getReportStartTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
getRepZkWrapper() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Get the ZK help of this manager
getRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
getRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
getRequest() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
 
getRequest() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
 
getRequest() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
getRequestCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getRequestCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
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.
getRequestParam() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
getRequestParam() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
getRequestParam() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
 
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
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
 
getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
 
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
 
getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
getRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
getRequestsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
getRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
 
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
 
getRequestUser() - Static method in class org.apache.hadoop.hbase.ipc.RequestContext
Returns the user credentials associated with the current RPC request or null if no credentials were provided.
getRequestUserName() - Static method in class org.apache.hadoop.hbase.ipc.RequestContext
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.coprocessor.CoprocessorClassLoader
 
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
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
 
getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
 
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
 
getRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
getRestVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
 
getResult() - Method in class org.apache.hadoop.hbase.client.Action
 
getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
getResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponseOrBuilder
 
getResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
getResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
getResult(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponseOrBuilder
 
getResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
getResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
getResult(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponseOrBuilder
 
getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
getResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponseOrBuilder
 
getResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
getResult(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
 
getResult() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
Obtain the processing result.
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.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.get_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.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.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.checkAndDelete_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndDelete
 
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.get_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.get
 
getResult(I, THBaseService.getMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getMultiple
 
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.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
 
getResultBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
getResultBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
getResultBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
getResultBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
getResultBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getResultBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
getResultBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
getResultBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
getResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
getResultCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponseOrBuilder
 
getResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
getResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
getResultCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponseOrBuilder
 
getResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
getResultCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
 
getResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
getResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
getResultList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponseOrBuilder
 
getResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
getResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
getResultList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponseOrBuilder
 
getResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
getResultList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
 
getResultOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
getResultOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
getResultOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponseOrBuilder
 
getResultOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
getResultOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
getResultOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponseOrBuilder
 
getResultOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
getResultOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
getResultOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponseOrBuilder
 
getResultOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
getResultOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
getResultOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponseOrBuilder
 
getResultOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getResultOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
getResultOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
 
getResultOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
getResultOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
getResultOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponseOrBuilder
 
getResultOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
getResultOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
getResultOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponseOrBuilder
 
getResultOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getResultOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
getResultOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
 
getResults() - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
getResults(ClientProtos.ScanResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the client Results from a protocol buffer ScanResponse
getResults(ClientProtos.MultiResponse, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Get the results from a protocol buffer MultiResponse
getResultSizeBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getResultSizeBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
getResultSizeBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
 
getRetCode() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
getRevision() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
Get the subversion revision number for the root directory
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
 
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
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
 
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getRootKeyZNode() - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
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.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.client.ServerCallable
Deprecated. Just use Object.toString() instead.
getRow() - Method in class org.apache.hadoop.hbase.KeyValue
Primarily for use client-side.
getRow() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
getRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
 
getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
getRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
 
getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
getRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellOrBuilder
 
getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
getRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValueOrBuilder
 
getRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
getRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
getRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
 
getRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
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.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.checkAndPut_args
row to check
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
 
getRowArray() - Method in interface org.apache.hadoop.hbase.Cell
Contiguous raw bytes that may start at any index in the containing array.
getRowArray(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
get individual arrays for tests
getRowArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getRowArray() - Method in class org.apache.hadoop.hbase.KeyValue
 
getRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
getRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
getRowBatchSize() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
 
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(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
Get the appropriate row comparator for the specified table.
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
 
getRowCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.Interface
 
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.
getRowKeyAtOrBefore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
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
 
getRowNum(RpcController, AggregateProtos.AggregateArgument, 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.
getRowNum(RpcController, AggregateProtos.AggregateArgument) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
 
getRowNum(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
getRowNum(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
 
getRowNum(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
 
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
 
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
Return the row that matches row exactly, or the one that immediately precedes it.
getRowOrBefore(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Deprecated. As of version 0.92 this method is deprecated without replacement. getRowOrBefore is used internally to find entries in .META. and makes various assumptions about the table (which are true for .META. but not in general) to be efficient.
getRowOrBefore(ClientProtocol, byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to get a row of the closet one before using client protocol.
getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getRowProcessorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
getRowProcessorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
getRowProcessorClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequestOrBuilder
 
getRowProcessorInitializerMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
getRowProcessorInitializerMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
getRowProcessorInitializerMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequestOrBuilder
 
getRowProcessorInitializerMessageName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
getRowProcessorInitializerMessageName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
getRowProcessorInitializerMessageName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequestOrBuilder
 
getRowProcessorPB(RowProcessor<S, T>) - Static method in class org.apache.hadoop.hbase.client.coprocessor.RowProcessorClient
 
getRowProcessorResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
getRowProcessorResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
getRowProcessorResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResultOrBuilder
 
getRowResource(String, String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
 
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
 
getRows(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
getRows(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
 
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
 
getRowsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
getRowsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
getRowsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
getRowsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
 
getRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
getRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
getRowsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
 
getRowsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
getRowsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
getRowsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
 
getRowsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
getRowsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
getRowsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
 
getRowsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
getRowsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
 
getRowsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
 
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>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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>) - 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>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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>) - 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.
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.
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() - Static method in class org.apache.hadoop.hbase.ipc.HBaseClientRPC
 
getRsCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
Return the RegionServer-level and Region-level coprocessors
gets - 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
getSaslQop() - Method in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.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
 
getScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
getScan() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
 
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.TableSplit
Returns a Scan object from the stored string representation.
getScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
getScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
getScan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgumentOrBuilder
 
getScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
getScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
getScan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
getScan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
the scan object to get a Scanner for
getScanBuilder() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
getScanBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
getScanBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
getScanForTableName(byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
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
 
getScanner(Scan) - Method in class org.apache.hadoop.hbase.client.HTable
Returns a scanner on the current table as specified by the Scan object.
getScanner(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Gets a scanner on the current table for the given family.
getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Gets a scanner on the current table for the given family and qualifier.
getScanner(Scan) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Returns a scanner on the current table as specified by the Scan object.
getScanner(byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Gets a scanner on the current table for the given family.
getScanner(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
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(Scan) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Return an iterator that scans over the HRegion, returning the indicated columns and rows specified by the Scan.
getScanner(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getScanner(Scan, NavigableSet<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getScanner(Scan, NavigableSet<byte[]>) - 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. 
getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
Deprecated. 
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.
getScannerCaching() - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. Use Scan.setCaching(int) and Scan.getCaching()
getScannerCallable(byte[], int) - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
getScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
getScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
getScannerId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
getScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
getScannerId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
 
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
 
getScannerResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
 
getScannerRows(int, int, AsyncMethodCallback<THBaseService.AsyncClient.getScannerRows_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
getScannerRows(int, int, AsyncMethodCallback<THBaseService.AsyncClient.getScannerRows_call>) - 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(boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[]) - 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(boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Get all scanners with no filtering based on TTL (that happens further down the line).
getScannersForStoreFiles(Collection<StoreFile>, boolean, boolean) - 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) - 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, ScanQueryMatcher) - 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
getScannersNoCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
Get a filtered list of scanners.
getScanOrBuilder() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
getScanOrBuilder() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
getScanOrBuilder() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
 
getScanOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
getScanOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
getScanOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgumentOrBuilder
 
getScanOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
getScanOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
getScanOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
getScanResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
getScanResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
getScanResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponseOrBuilder
 
getScans() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Allows subclasses to get the list of Scan objects.
getSchemaAlterStatus(RpcController, MasterMonitorProtos.GetSchemaAlterStatusRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
Get the number of regions of the table that have been updated by the alter.
getSchemaAlterStatus(RpcController, MasterMonitorProtos.GetSchemaAlterStatusRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService.BlockingInterface
 
getSchemaAlterStatus(RpcController, MasterMonitorProtos.GetSchemaAlterStatusRequest, RpcCallback<MasterMonitorProtos.GetSchemaAlterStatusResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService
 
getSchemaAlterStatus(RpcController, MasterMonitorProtos.GetSchemaAlterStatusRequest, RpcCallback<MasterMonitorProtos.GetSchemaAlterStatusResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService.Interface
 
getSchemaAlterStatus(RpcController, MasterMonitorProtos.GetSchemaAlterStatusRequest, RpcCallback<MasterMonitorProtos.GetSchemaAlterStatusResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService.Stub
 
getSchemaResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
 
getScope() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getScopes() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
getScopeType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
getScopeType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
getScopeType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScopeOrBuilder
 
getSecond() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
getSecond() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
getSecond() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPairOrBuilder
 
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
 
getSecondPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
getSecondPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
getSecondPart() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponseOrBuilder
 
getSecretManager() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
 
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
 
getSeqNumDuringOpen(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
The latest seqnum that the server writing to meta observed when opening the region.
getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
getSequenceID() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Get the sequence id associated with this KeyValueScanner.
getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
MemStoreScanner returns max value as sequence id because it will always have the latest data among all files.
getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
getSequenceID() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
getSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
getSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
getSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
 
getSequenceNumber() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
 
getSequenceNumber() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getSerializedComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
getSerializedComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
getSerializedComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ComparatorOrBuilder
 
getSerializedFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
getSerializedFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
getSerializedFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FilterOrBuilder
 
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.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.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(Class<? extends IpcProtocol>, Object, Class<?>[], String, int, int, int, boolean, Configuration, int) - Static method in class org.apache.hadoop.hbase.ipc.HBaseServerRPC
Construct a server for a protocol implementation instance.
getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
getServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
 
getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
getServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
 
getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
getServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder
 
getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
getServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServerOrBuilder
 
getServerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
getServerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
getServerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
getServerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
getServerCurrentTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
getServerCurrentTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
getServerCurrentTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
 
getServerInfo() - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated. Use ClusterStatus.getServers()
getServerInfo(RpcController, AdminProtos.GetServerInfoRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
 
getServerInfo(RpcController, AdminProtos.GetServerInfoRequest, RpcCallback<AdminProtos.GetServerInfoResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
getServerInfo(RpcController, AdminProtos.GetServerInfoRequest, RpcCallback<AdminProtos.GetServerInfoResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
 
getServerInfo(RpcController, AdminProtos.GetServerInfoRequest, RpcCallback<AdminProtos.GetServerInfoResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
getServerInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
getServerInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
getServerInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponseOrBuilder
 
getServerInfo(AdminProtocol) - 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.HRegionServer
Get some information of the region server.
getServerInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
getServerInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
getServerInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
getServerInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponseOrBuilder
 
getServerLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
getServerLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
getServerLoad() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
 
getServerLoadBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
getServerLoadOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
getServerLoadOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
getServerLoadOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
 
getServerManager() - Method in class org.apache.hadoop.hbase.master.HMaster
 
getServerManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getServerName() - Method in class org.apache.hadoop.hbase.client.ServerCallable
Deprecated. Just use Object.toString() instead.
getServerName() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
 
getServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Returns a ServerName from catalog table Result.
getServerName() - Method in class org.apache.hadoop.hbase.HRegionLocation
 
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.RegionState
 
getServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
getServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
getServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfoOrBuilder
 
getServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
getServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
getServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
 
getServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
getServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
getServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
 
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, int, long) - Static 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
 
getServerNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
getServerNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
getServerNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
getServerNameFromHLogDirectoryName(Configuration, String) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogUtil
 
getServerNameLessStartCode(String) - Static method in class org.apache.hadoop.hbase.ServerName
Utility method to excise the start code from a server name
getServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
getServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
getServerNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfoOrBuilder
 
getServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
getServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
getServerNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
 
getServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
getServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
getServerNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
 
getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
getServerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
 
getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
getServerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
 
getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
getServerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder
 
getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
getServerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServerOrBuilder
 
getServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
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
 
getServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
getServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
getServerStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
 
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(CatalogTracker, ServerName) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
 
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
 
getServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
getServerVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
 
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.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 class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
getService() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
getService() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
 
getService() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
getService() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
getService() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProtoOrBuilder
 
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
 
getServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
getServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
getServiceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
 
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
 
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
 
getShortMidpointKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
Generate a faked byte array if possible.
getShortMidpointKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.MetaKeyComparator
 
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.
getShowAppendWarning() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getShowAppendWarning__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
getSingleColumnValueFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
getSingleColumnValueFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
getSingleColumnValueFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilterOrBuilder
 
getSingleColumnValueFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
getSingleColumnValueFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
getSingleColumnValueFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
getSingleColumnValueFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilterOrBuilder
 
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.ImmutableBytesWritable
 
getSize() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
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 interface org.apache.hadoop.hbase.regionserver.Store
 
getSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
 
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
 
getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
getSlavesAddresses(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Returns all region servers from given peer
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
 
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
 
getSnapshot() - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
getSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequestOrBuilder
 
getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
getSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequestOrBuilder
 
getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
getSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequestOrBuilder
 
getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
getSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponseOrBuilder
 
getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
getSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequestOrBuilder
 
getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
getSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequestOrBuilder
 
getSnapshotBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
getSnapshotBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
getSnapshotBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
getSnapshotBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
getSnapshotBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
getSnapshotBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
getSnapshotDescription() - Method in exception org.apache.hadoop.hbase.exceptions.HBaseSnapshotException
 
getSnapshotHLogsDir(Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.TakeSnapshotUtils
Get the log directory for a specific snapshot
getSnapshotManagerForTesting() - Method in class org.apache.hadoop.hbase.master.HMaster
Exposed for TESTING!
getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
getSnapshotOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequestOrBuilder
 
getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
getSnapshotOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequestOrBuilder
 
getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
getSnapshotOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequestOrBuilder
 
getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
getSnapshotOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponseOrBuilder
 
getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
getSnapshotOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequestOrBuilder
 
getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
getSnapshotOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequestOrBuilder
 
getSnapshotRegionNames(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Returns the set of region names available in the snapshot.
getSnapshotRootDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Get the snapshot root directory.
getSnapshots(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
getSnapshots(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
getSnapshots(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponseOrBuilder
 
getSnapshotsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
getSnapshotsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
getSnapshotsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
getSnapshotsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
getSnapshotsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponseOrBuilder
 
getSnapshotsDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
 
getSnapshotsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
getSnapshotsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
getSnapshotsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponseOrBuilder
 
getSnapshotsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
getSnapshotsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
getSnapshotsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponseOrBuilder
 
getSnapshotsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
getSnapshotsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
getSnapshotsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponseOrBuilder
 
getSnapshotTimeRangeTracker() - Method in class org.apache.hadoop.hbase.regionserver.MemStore
 
getSortedIndexForInsertionId(int) - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
 
getSortedPrefixes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
getSortedPrefixes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
getSortedPrefixes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilterOrBuilder
 
getSortedPrefixesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
getSortedPrefixesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
getSortedPrefixesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilterOrBuilder
 
getSortedPrefixesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
getSortedPrefixesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
getSortedPrefixesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilterOrBuilder
 
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 class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
getSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
getSource() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
 
getSource() - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
getSource() - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
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
getSpec() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
getSpec() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
getSpec() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
 
getSpecBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
getSpecOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
getSpecOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
getSpecOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
 
getSplit() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
getSplit() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
getSplit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
 
getSplitEditFilesSorted(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogUtil
Returns sorted set of edit files made by wal-log splitter, excluding files with '.temp' suffix.
getSplitKey() - Method in class org.apache.hadoop.hbase.io.Reference
 
getSplitkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
getSplitkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
getSplitkey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.ReferenceOrBuilder
 
getSplitKeys(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
getSplitKeys(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
getSplitKeys(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequestOrBuilder
 
getSplitKeysArray(MasterAdminProtos.CreateTableRequest) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
get the split keys in form "byte [][]" from a CreateTableRequest proto
getSplitKeysCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
getSplitKeysCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
getSplitKeysCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequestOrBuilder
 
getSplitKeysList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
getSplitKeysList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
getSplitKeysList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequestOrBuilder
 
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
 
getSplitPoint() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
getSplitPoint() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
getSplitPoint() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequestOrBuilder
 
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.
getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated. Calculates the splits that will serve as input for the map tasks.
getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
 
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.TableInputFormatBase
Calculates the splits that will serve as input for the map tasks.
getSplits() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
 
getStackTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
getStackTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
getStackTrace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
 
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
 
getStamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
getStamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
getStamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
 
getStart() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
 
getStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
getStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
getStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
 
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
 
getStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
getStartCode() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
getStartcode() - Method in class org.apache.hadoop.hbase.ServerName
 
getStartDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
getStartDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
getStartDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUpOrBuilder
 
getStartEndKeys() - Method in class org.apache.hadoop.hbase.client.HTable
Gets the starting and ending row keys for every region in the currently open table.
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.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
getStartKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
getStartKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
 
getStartKey() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getStartKey() - Method in class org.apache.hadoop.hbase.regionserver.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
 
getStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
getStartKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
 
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.HTable
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
Deprecated.  
getStartRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the start row.
getStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getStartRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
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
 
getStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getStartRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
getStartRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
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.ipc.HBaseClient.Call
 
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.rest.model.ScannerModel
 
getStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
getStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
getStartTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
getStartTime() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
getState() - Method in class org.apache.hadoop.hbase.master.RegionState
 
getState() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
getState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
 
getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
getState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationStateOrBuilder
 
getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
getState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
 
getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
getState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableOrBuilder
 
getState() - Method in class org.apache.hadoop.hbase.replication.ReplicationStateImpl
 
getState() - Method in interface org.apache.hadoop.hbase.replication.ReplicationStateInterface
Get the current state of replication (i.e.
getState() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
getStateTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
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.DoubleBlockCache
 
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.SimpleBlockCache
 
getStats() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
getStats() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
 
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
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 class org.apache.hadoop.hbase.procedure.Procedure
 
getStatusTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
getStd(RpcController, AggregateProtos.AggregateArgument, 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.
getStd(RpcController, AggregateProtos.AggregateArgument) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
 
getStd(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
getStd(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
 
getStd(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
 
getStdDev() - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
getStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
 
getStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getStopRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getStopRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getStopRowKey() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
getStopRowKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
getStopRowKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
getStopRowKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilterOrBuilder
 
getStore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Return HStore instance.
getStoreArchivePath(Configuration, String, 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
 
getStoreFile(RpcController, AdminProtos.GetStoreFileRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
 
getStoreFile(RpcController, AdminProtos.GetStoreFileRequest, RpcCallback<AdminProtos.GetStoreFileResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
getStoreFile(RpcController, AdminProtos.GetStoreFileRequest, RpcCallback<AdminProtos.GetStoreFileResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
 
getStoreFile(RpcController, AdminProtos.GetStoreFileRequest, RpcCallback<AdminProtos.GetStoreFileResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
getStoreFile(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
getStoreFile(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
getStoreFile(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponseOrBuilder
 
getStoreFile(RpcController, AdminProtos.GetStoreFileRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getStoreFileCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
getStoreFileCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
getStoreFileCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponseOrBuilder
 
getStorefileCount() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Returns the number of files currently in use.
getStoreFileIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the Size of indexes in storefiles on disk.
getStorefileIndexSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
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
 
getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
getStoreFileList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
getStoreFileList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
getStoreFileList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponseOrBuilder
 
getStoreFileList(byte[][]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Return list of storeFiles for the set of CFs.
getStoreFileManager() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
getStoreFileOpenAndCloseThreadPool(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getStorefiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getStorefiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getStorefiles() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
getStoreFiles(AdminProtocol, 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(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
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.rest.model.StorageClusterStatusModel.Node.Region
 
getStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
getStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getStorefiles() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
getStorefiles() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStoreFileScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
Get a scanner to scan over this StoreFile.
getStoreFileScanner(boolean, boolean, 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
 
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.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
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
 
getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
getStorefilesSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getStorefilesSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
getStoreFileTtl() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getStoreFileTtl() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
Gets the cf-specific time-to-live for store files.
getStoreFlusher(long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getStoreFlusher(long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
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. 
getStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getStoreLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getStoreLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getStoreOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getStoreOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getStoreOpenAndCloseThreadPool(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getStores() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
getStores() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
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
 
getStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getStores() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
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
 
getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getStoreUncompressedSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getStringCollection(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
getStrings(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
getStrings(String, String...) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
getStructuralString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
getSubstr() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
getSubstr() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
getSubstr() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparatorOrBuilder
 
getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_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.getMultiple_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.thrift2.generated.THBaseService.deleteMultiple_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.getScannerRows_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.getMultiple_result
 
getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
getSum(RpcController, AggregateProtos.AggregateArgument, 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.
getSum(RpcController, AggregateProtos.AggregateArgument) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
 
getSum(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
getSum(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
 
getSum(RpcController, AggregateProtos.AggregateArgument, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
 
getSumHitCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getSumHitCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getSumRequestCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getSumRequestCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
getSupportedAlgorithms() - Static method in class org.apache.hadoop.hbase.io.compress.Compression
Get names of supported compression 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
getSynchronous() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
getSynchronous() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
getSynchronous() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequestOrBuilder
 
getTable(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
Get a reference to the specified table from the pool.
getTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HTablePool
Get a reference to the specified table from the pool.
getTable(byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
Open a table from within the Coprocessor environment
getTable(byte[]) - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getTable() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
 
getTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
getTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
getTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
 
getTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
getTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
getTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequestOrBuilder
 
getTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
getTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
getTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
 
getTable() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
getTable() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
getTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Creates and returns an HTable 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.checkAndDelete_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.get_args
the table to get from
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.increment_args
the table to increment the value on
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
getTableArchivePath(Path) - 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(Path, String) - 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, String) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
Get the path to the table archive directory based on the configured archive directory.
getTableDesc() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
getTableDescriptor(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Method for getting the tableDescriptor
getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HTable
Gets the table descriptor for this table.
getTableDescriptor() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Gets the table descriptor for this table.
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(FileSystem, Path, byte[]) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Get HTD from HDFS.
getTableDescriptor(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
 
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, MasterMonitorProtos.GetTableDescriptorsRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
Get list of TableDescriptors for requested tables.
getTableDescriptors() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
getTableDescriptors(RpcController, MasterMonitorProtos.GetTableDescriptorsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService.BlockingInterface
 
getTableDescriptors(RpcController, MasterMonitorProtos.GetTableDescriptorsRequest, RpcCallback<MasterMonitorProtos.GetTableDescriptorsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService
 
getTableDescriptors(RpcController, MasterMonitorProtos.GetTableDescriptorsRequest, RpcCallback<MasterMonitorProtos.GetTableDescriptorsResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService.Interface
 
getTableDescriptors(RpcController, MasterMonitorProtos.GetTableDescriptorsRequest, RpcCallback<MasterMonitorProtos.GetTableDescriptorsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService.Stub
 
getTableDir(Path, byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
Returns the Path object representing the table directory under path rootdir
getTableDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
 
getTableDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
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.
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
Looks under the table directory in the filesystem for files with a FSTableDescriptors.TABLEINFO_NAME prefix.
getTableLockManager() - Method in class org.apache.hadoop.hbase.master.HMaster
 
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.ClientScanner
 
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
Gets the name of this table.
getTableName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Gets the table name from the specified region name.
getTableName() - Method in class org.apache.hadoop.hbase.HRegionInfo
Get current table name of the region
getTableName() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
getTableName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Returns the table name.
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKeyOrBuilder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequestOrBuilder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequestOrBuilder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequestOrBuilder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequestOrBuilder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequestOrBuilder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequestOrBuilder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequestOrBuilder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequestOrBuilder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequestOrBuilder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
 
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.Store
 
getTablename() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
 
getTableName() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getTableName() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
getTableNameAsString() - Method in class org.apache.hadoop.hbase.HRegionInfo
Get current table name as string
getTableNames(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
getTableNames(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
getTableNames(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequestOrBuilder
 
getTableNames() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getTableNamesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
getTableNamesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
getTableNamesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequestOrBuilder
 
getTableNamesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
getTableNamesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
getTableNamesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequestOrBuilder
 
getTablePath(Path, byte[]) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getTablePath(Path, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
getTableRegions(CatalogTracker, byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
Gets all of the regions of the specified table.
getTableRegions(CatalogTracker, byte[], boolean) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
Gets all of the regions of the specified table.
getTableRegions(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
get the regions of a given table.
getTableRegions(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getTableRegionsAndLocations(CatalogTracker, String) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
 
getTableRegionsAndLocations(CatalogTracker, byte[], boolean) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
 
getTableResource(String) - Method in class org.apache.hadoop.hbase.rest.RootResource
 
getTables() - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
 
getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
getTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequestOrBuilder
 
getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
getTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequestOrBuilder
 
getTableSchema(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
getTableSchema(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
getTableSchema(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponseOrBuilder
 
getTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
getTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
getTableSchemaBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
getTableSchemaBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
getTableSchemaCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
getTableSchemaCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
getTableSchemaCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponseOrBuilder
 
getTableSchemaList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
getTableSchemaList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
getTableSchemaList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponseOrBuilder
 
getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
getTableSchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequestOrBuilder
 
getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
getTableSchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequestOrBuilder
 
getTableSchemaOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
getTableSchemaOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
getTableSchemaOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponseOrBuilder
 
getTableSchemaOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
getTableSchemaOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
getTableSchemaOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponseOrBuilder
 
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.
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).
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
 
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.
getTempDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
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.
getThreadId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
getThreadId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
getThreadId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
 
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
 
getThreadReadPoint() - Static method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
Get this thread's read point.
getThreadWakeFrequency() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Interval at which threads should run
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.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.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.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.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.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.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.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.TPut._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
 
getTime() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
 
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.protobuf.generated.ClientProtos.Get.Builder
 
getTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
getTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
getTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
getTimeRangeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getTimeRangeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getTimeRangeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getTimeRangeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
getTimeRangeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
getTimeRangeOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
getTimeRangeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getTimeRangeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getTimeRangeOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getTimeRangeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
getTimeRangeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
getTimeRangeOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
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
 
getTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
getTimestamp() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
 
getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue
 
getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
getTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
 
getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
getTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellOrBuilder
 
getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
getTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValueOrBuilder
 
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
 
getTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
getTimestamp() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
 
getTimestamp() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
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(int) - Method in class org.apache.hadoop.hbase.KeyValue
 
getTimestamps() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getTimestamps() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
getTimestamps(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
getTimestamps(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
getTimestamps(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilterOrBuilder
 
getTimestampsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
getTimestampsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
getTimestampsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilterOrBuilder
 
getTimestampsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
getTimestampsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
getTimestampsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilterOrBuilder
 
getTimestampString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
getTimeToLive() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
getTimeToPurgeDeletes() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
 
getTo() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
getTo() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
getTo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRangeOrBuilder
 
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() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
getToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
getToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponseOrBuilder
 
getTokenArrayOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getTokenBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
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
getTokenOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
getTokenOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
getTokenOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponseOrBuilder
 
getTop(int) - Method in class org.apache.hadoop.hbase.metrics.ExactCounterMetric
Deprecated.  
getTopHosts() - 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
 
getTotalBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getTotalColumnLength() - Method in class org.apache.hadoop.hbase.KeyValue
 
getTotalColumnLength(int, int) - Method in class org.apache.hadoop.hbase.KeyValue
 
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
 
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
 
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
 
getTotalCompressedBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
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.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getTotalNumberOfRequests() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
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
 
getTotalRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
getTotalRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
getTotalRegions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponseOrBuilder
 
getTotalRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the total number of requests per second.
getTotalRequestsCount(HBaseProtos.RegionLoad) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
getTotalSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
getTotalStaticBloomSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
getTotalStaticBloomSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the size 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.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
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
 
getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
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 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.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
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
 
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
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.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getTotalUncompressedBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
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.
getTrace(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
getTrace(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
getTrace(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
 
getTraceBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
getTraceBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
getTraceCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
getTraceCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
getTraceCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
 
getTraceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
getTraceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
getTraceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfoOrBuilder
 
getTraceInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
getTraceInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
getTraceInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
 
getTraceInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
getTraceInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
getTraceInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
getTraceInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
 
getTraceList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
getTraceList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
getTraceList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
 
getTraceOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
getTraceOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
getTraceOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
 
getTraceOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
getTraceOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
getTraceOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
 
getTrailer() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
 
getTrailer() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
getTrailerSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getTransitionInZK() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
getTransitionInZK() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
getTransitionInZK() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
 
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
 
getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
getTtl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
getTtl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
getTtl() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
 
getTtl() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
 
getTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
getTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
getTtl() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
 
getType(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
getType() - Method in class org.apache.hadoop.hbase.KeyValue
 
getType() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
getType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifierOrBuilder
 
getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
getType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
 
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
 
getTypeBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getTypeString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
getUGI() - Method in class org.apache.hadoop.hbase.security.User
 
getUncaughtExceptionHandler() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
 
getUncaughtExceptionHandler() - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
 
getUncompressedBytesWithHeader() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
getUncompressedBytesWithHeader() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
 
getUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
getUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
getUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
getUncompressedDataIndexSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
getUncompressedSizeWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
getUniqueBlocksTotalWeight() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
 
getUniqueFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
 
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.
getUsedHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
getUsedHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
getUsedHeapMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
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.ipc.RequestContext
 
getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
getUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionOrBuilder
 
getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
getUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissionsOrBuilder
 
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.
getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
getUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
 
getUserInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
getUserInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
 
getUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
getUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
getUsername() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
 
getUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
getUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
getUsername() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponseOrBuilder
 
getUsername() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
getUserPermissions(RpcController, AccessControlProtos.UserPermissionsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface
 
getUserPermissions(RpcController, AccessControlProtos.UserPermissionsRequest, RpcCallback<AccessControlProtos.UserPermissionsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
 
getUserPermissions(RpcController, AccessControlProtos.UserPermissionsRequest, RpcCallback<AccessControlProtos.UserPermissionsResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Interface
 
getUserPermissions(RpcController, AccessControlProtos.UserPermissionsRequest, RpcCallback<AccessControlProtos.UserPermissionsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Stub
 
getUserPermissions(AccessControlProtos.AccessControlService.BlockingInterface, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to get user permissions.
getUserPermissions(RpcController, AccessControlProtos.UserPermissionsRequest, RpcCallback<AccessControlProtos.UserPermissionsResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
getUtf8ByteArrays(List<String>) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
getUUIDForCluster(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Get the UUID for the provided ZK watcher.
getValue(byte[], byte[], KeyValue) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
getValue(byte[], byte[], KeyValue) - 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(byte[], byte[], KeyValue) - 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
Returns value in a new byte array.
getValue() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
getValue() - Method in class org.apache.hadoop.hbase.metrics.MetricsString
Deprecated.  
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResultOrBuilder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparableOrBuilder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellOrBuilder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValueOrBuilder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPairOrBuilder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64PairOrBuilder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPairOrBuilder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifierOrBuilder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponseOrBuilder
 
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
 
getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
getValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
 
getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
getValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
 
getValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
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 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.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(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
getValueArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
getValueArray() - Method in class org.apache.hadoop.hbase.KeyValue
 
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.
getValueAsByteBuffer() - Method in class org.apache.hadoop.hbase.KeyValue
Returns the value wrapped in a new ByteBuffer.
getValueBufferShallowCopy(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
getValueBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
getValueBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
getValueByteRange() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.ScopeType
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
 
getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
 
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
 
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
 
getValueOffsetWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
getValueOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
getValueOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
getValueOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResultOrBuilder
 
getValueOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
getValueOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
getValueOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
 
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
 
getValues(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
getValues(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
 
getValuesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getValuesBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getValuesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getValuesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
getValuesCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
 
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.
getValuesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getValuesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
getValuesList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
 
getValuesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getValuesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
getValuesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
 
getValuesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
getValuesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
getValuesOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
 
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>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Deprecated. 
getVer(ByteBuffer, ByteBuffer, byte[], byte[], int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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.coprocessor.CoprocessorHost.Environment
 
getVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
 
getVersion() - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated. HRI is no longer a VersionedWritable
getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
getVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContentOrBuilder
 
getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
getVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
 
getVersion() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
 
getVersion() - Method in class org.apache.hadoop.hbase.security.access.Permission
 
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
 
getVersionOfClosingNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
getVersionOfClosingNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
getVersionOfClosingNode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
 
getVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
getVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
getVersionOfOfflineNode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
 
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
 
getVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
getVersionsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
 
getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Deprecated. 
getVerTs(ByteBuffer, ByteBuffer, byte[], byte[], long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
getWAL() - Method in interface org.apache.hadoop.hbase.coprocessor.WALCoprocessorEnvironment
 
getWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getWAL(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getWAL(HRegionInfo) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
getWALActionListeners() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Called by HRegionServer.instantiateHLog(Path, String) setting up WAL instance.
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
 
getWalEdit(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
 
getWatcher() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
getWebAppsPath(String) - Method in class org.apache.hadoop.hbase.util.InfoServer
Get the pathname to the webapps files.
getWebAppsPath() - Method in class org.apache.hadoop.hbase.util.InfoServer
Get the pathname to the path files.
getWebuiPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
getWebuiPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
getWebuiPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfoOrBuilder
 
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.
getWorkingSnapshotDir(Path) - 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) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Get the directory to build a snapshot, before it is finalized
getWorkingSnapshotDir(String, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Get the directory to build a snapshot, before it is finalized
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.
getWriteBuffer() - Method in class org.apache.hadoop.hbase.client.HTable
Returns the write buffer.
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
Returns the maximum size in bytes of the write buffer for this HTable.
getWriteBufferSize() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
getWriteLatenciesNanos() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
getWriteOps() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
getWriter() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
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
 
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
 
getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
Get the number of write requests to regions hosted on this region server.
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
 
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
 
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.
getWriterFSDataOutputStream() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
 
getWriteTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
getWriteTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
getWriteTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKeyOrBuilder
 
getWriteTime() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
 
getWriteTimeMs() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
getWriteToWAL() - Method in class org.apache.hadoop.hbase.client.Mutation
 
getWriteToWAL() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
getWriteToWAL() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
getWriteToWAL() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
getYetToUpdateRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
getYetToUpdateRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
getYetToUpdateRegions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponseOrBuilder
 
getZkController() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
 
getZKPermissionWatcher() - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
getZKQuorumServersString(Properties) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
Return the ZK Quorum servers string given zk properties returned by makeZKProps
getZKQuorumServersString(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
Return the ZK Quorum servers string given the specified configuration.
getZKTable() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
getZkw() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
Get the ZK connection to this peer
getZNodeName(String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Extracts the znode name of a peer cluster from a ZK path
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.ZKUtil
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.ZKUtil
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
 
getZooKeeperWatcher() - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated. Removed because it was a mistake exposing zookeeper in this interface (ZooKeeper is an implementation detail). Deprecated in HBase 0.94
getZooKeeperWatcher() - Method in class org.apache.hadoop.hbase.master.HMaster
Get the ZK wrapper object - needed by master_jsp.java
getZooKeeperWatcher() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
getZookeeperWatcher() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Get this cluster's zk connection
globalStartTime - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
grant(RpcController, AccessControlProtos.GrantRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface
 
grant(RpcController, AccessControlProtos.GrantRequest, RpcCallback<AccessControlProtos.GrantResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
 
grant(RpcController, AccessControlProtos.GrantRequest, RpcCallback<AccessControlProtos.GrantResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Interface
 
grant(RpcController, AccessControlProtos.GrantRequest, RpcCallback<AccessControlProtos.GrantResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Stub
 
grant(AccessControlProtos.AccessControlService.BlockingInterface, String, byte[], byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to grant a user some permissions.
grant(RpcController, AccessControlProtos.GrantRequest, RpcCallback<AccessControlProtos.GrantResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
GREATER_OR_EQUAL_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
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
 
GREATER_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Deprecated. 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.
GROUP_PREFIX - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
Prefix character to denote group names
GroupingTableMap - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
GroupingTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.GroupingTableMap
Deprecated.  
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, HTable, 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.
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
 
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, DataBlockEncoding) - Constructor for class org.apache.hadoop.hbase.io.HalfStoreFileReader
Creates a half file reader for a normal hfile.
HalfStoreFileReader(FileSystem, Path, FSDataInputStream, FSDataInputStream, long, CacheConfig, Reference, DataBlockEncoding) - 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).
handleCreateHdfsRegions(Path, String) - 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, String) - 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.
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.
handleLockMetadata(String) - 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
 
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.
handleRegionsMergeReport(ServerName, HRegionInfo, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Update inmemory structures.
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.
handleReportForDutyResponse(RegionServerStatusProtos.RegionServerStartupResponse) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
handleSplitReport(ServerName, HRegionInfo, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Update inmemory structures.
handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
 
handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.ModifyTableHandler
 
handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableAddFamilyHandler
 
handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableDeleteFamilyHandler
 
handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableModifyFamilyHandler
 
handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
The restore table is executed in place.
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.
hasAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
hasAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
hasAssignSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
 
hasAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
hasAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
hasAssignSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
 
hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
hasAssociatedCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
hasAssociatedCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
 
hasAtomic() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
hasAtomic() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
hasAtomic() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
 
hasAuthMethod() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
hasAuthMethod() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
hasAuthMethod() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponseOrBuilder
 
hasAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
hasAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
hasAverageLoad() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
hasBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
hasBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
hasBalancerOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
hasBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
hasBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
hasBalancerOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerStateOrBuilder
 
hasBalancerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
hasBalancerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
hasBalancerRan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponseOrBuilder
 
hasBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
hasBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
hasBatch() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
hasBatchSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
hasBatchSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
hasBatchSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
hasBigdecimalMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
hasBigdecimalMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
hasBigdecimalMsg() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsgOrBuilder
 
hasBitwiseOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
hasBitwiseOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
hasBitwiseOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparatorOrBuilder
 
hasBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
 
hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
hasBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequestOrBuilder
 
hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
hasBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponseOrBuilder
 
hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
hasBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
 
hasCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
hasCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
hasCacheBlocks() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
hasCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
hasCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
hasCacheBlocks() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
hasCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
hasCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
hasCaching() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
hasCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
hasCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
hasCall() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
 
hasCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
hasCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
hasCallId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
 
hasCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
hasCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
hasCallId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
 
hasCellBlockCodecClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
hasCellBlockCodecClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
hasCellBlockCodecClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
 
hasCellBlockCompressorClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
hasCellBlockCompressorClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
hasCellBlockCompressorClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
 
hasCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
hasCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
hasCellBlockMeta() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
 
hasCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
hasCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
hasCellBlockMeta() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
 
hasCellType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
hasCellType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
hasCellType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellOrBuilder
 
hasChance() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
hasChance() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
hasChance() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilterOrBuilder
 
hasCharset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
hasCharset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
hasCharset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
 
hasChildren() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
hasClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
hasClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
hasClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
 
hasClosed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
hasClosed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
hasClosed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponseOrBuilder
 
hasCloseScanner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
hasCloseScanner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
hasCloseScanner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
hasClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
hasClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
hasClosestRowBefore() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
 
hasClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
hasClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
hasClosestRowBefore() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequestOrBuilder
 
hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
hasClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKeyOrBuilder
 
hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
hasClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterIdOrBuilder
 
hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
hasClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
hasClusterkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
hasClusterkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
hasClusterkey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
 
hasClusterStatus() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
hasClusterStatus() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
hasClusterStatus() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponseOrBuilder
 
hasColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
hasColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
hasColumn() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
 
hasColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
hasColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
hasColumnFamilies() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequestOrBuilder
 
hasColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
hasColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
hasColumnFamilies() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequestOrBuilder
 
hasColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
hasColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
hasColumnFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
 
hasColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
hasColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
hasColumnFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
 
hasColumnName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
hasColumnName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
hasColumnName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequestOrBuilder
 
hasColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
hasColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
hasColumnQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
 
hasColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
hasColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
hasColumnQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
 
hasColumns() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
hasCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
hasCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
hasCompactionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequestOrBuilder
 
hasCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
hasCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
hasCompactionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
 
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
hasComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparatorOrBuilder
 
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
hasComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparatorOrBuilder
 
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
hasComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparatorOrBuilder
 
hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
hasComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
 
hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
hasComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilterOrBuilder
 
hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
hasComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
 
hasComparatorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
hasComparatorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
hasComparatorClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
 
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilterOrBuilder
 
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilterOrBuilder
 
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilterOrBuilder
 
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilterOrBuilder
 
hasCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
hasCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
hasCompareOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilterOrBuilder
 
hasCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
hasCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
hasCompareOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
 
hasCompareType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
hasCompareType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
hasCompareType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
 
hasCompleteSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasCompleteSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasCompleteSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
hasCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
hasCompression() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
 
hasCompressionCodec() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
hasCompressionCodec() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
hasCompressionCodec() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
hasCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
hasCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
hasCondition() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
 
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
 
hasCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
hasCount() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponseOrBuilder
 
hasCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
hasCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
hasCreateTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
 
hasCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
hasCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
hasCreationTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
 
hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
hasData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
hasData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
hasData() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
 
hasDataIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
hasDataIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
hasDataIndexCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
hasDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
hasDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
hasDeclaringClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
 
hasDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
hasDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
hasDeleteType() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
 
hasDeleteType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
hasDeleteType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
hasDeleteType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
 
hasDestinationServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
hasDestinationServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
hasDestinationServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
 
hasDestServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
hasDestServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
hasDestServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequestOrBuilder
 
hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
hasDone() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponseOrBuilder
 
hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
hasDone() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponseOrBuilder
 
hasDoNotRetry() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
hasDoNotRetry() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
hasDoNotRetry() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
 
hasDropDependentColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
hasDropDependentColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
hasDropDependentColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
 
hasEdit() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
hasEdit() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
hasEdit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
 
hasEffectiveUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
hasEffectiveUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
hasEffectiveUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformationOrBuilder
 
hasEnable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
hasEnable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
hasEnable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequestOrBuilder
 
hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
hasEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKeyOrBuilder
 
hasEndKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
hasEndKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
hasEndKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
 
hasEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
hasEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
hasEndKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
 
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
 
hasEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
hasEndRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
hasEndRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
hasEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
hasEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
hasEndTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
hasEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
hasEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
hasEntryCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
hasErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
hasErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
hasErrorInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
 
hasErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
hasErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
hasErrorMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder
 
hasEventTypeCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
hasEventTypeCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
hasEventTypeCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
 
hasException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
 
hasException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
Non-exceptional form of ForeignExceptionSnare.rethrowException().
hasException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
hasException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResultOrBuilder
 
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
hasException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
 
hasException() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTask
 
hasException() - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
Check if an exception has occurred when re-setting the watch.
hasExceptionClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
hasExceptionClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
hasExceptionClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
 
hasExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
hasExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
hasExistenceOnly() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
 
hasExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
hasExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
hasExistenceOnly() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequestOrBuilder
 
hasExists() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
hasExists() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
hasExists() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponseOrBuilder
 
hasExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
hasExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
hasExpectedTimeout() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponseOrBuilder
 
hasExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
hasExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
hasExpirationDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
 
hasExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
hasExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
hasExpirationDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
 
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.protobuf.generated.AccessControlProtos.Permission.Builder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScopeOrBuilder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPathOrBuilder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ColumnOrBuilder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellOrBuilder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValueOrBuilder
 
hasFamily() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasFan() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
hasFileInfoOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
hasFileInfoOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
hasFileInfoOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
hasFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
hasFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
hasFileName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
 
hasFilter() - Method in class org.apache.hadoop.hbase.client.Scan
 
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapperOrBuilder
 
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilterOrBuilder
 
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilterOrBuilder
 
hasFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
hasFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
hasFilter() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
hasFilterIfMissing() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
hasFilterIfMissing() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
hasFilterIfMissing() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
 
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 KeyValues 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.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
 
hasFirst() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
hasFirst() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
hasFirst() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPairOrBuilder
 
hasFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
hasFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
hasFirstDataBlockOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
hasFlushed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
hasFlushed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
hasFlushed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponseOrBuilder
 
hasForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
hasForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
hasForce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequestOrBuilder
 
hasForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
hasForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
hasForcible() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
 
hasForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
hasForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
hasForcible() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequestOrBuilder
 
hasFoundKV() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
hasFrom() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
hasFrom() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
hasFrom() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRangeOrBuilder
 
hasFsToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
hasFsToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
hasFsToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
 
hasGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
hasGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
hasGenericException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
 
hasGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
hasGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
hasGet() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
 
hasGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
hasGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
hasGet() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiActionOrBuilder
 
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.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
 
hasHbaseVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
hasHbaseVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
hasHbaseVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
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.HConnectionManager.HConnectionKey
 
hashCode() - Method in class org.apache.hadoop.hbase.client.Increment
 
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.NullComparator
 
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.hfile.BlockCacheColumnFamilySummary
 
hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
hashCode() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
hashCode() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.ConnectionId
 
hashCode() - Method in class org.apache.hadoop.hbase.KeyValue
 
hashCode() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.wal.HLogKey
 
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.AuthenticationTokenIdentifier
 
hashCode() - Method in class org.apache.hadoop.hbase.security.User
 
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.thrift.CallQueue.Call
 
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.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.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.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.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.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.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 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.TPut
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
hashCode() - Method in class org.apache.hadoop.hbase.util.ByteRange
 
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.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.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
 
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
 
hasHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
hasHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
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
hasHostName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
hasHostName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
hasHostName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
 
hasHostname() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
hasHostname() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
hasHostname() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
 
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.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
hasId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
hasId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
 
hasId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
hasId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
hasId() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
 
hasId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
hasIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
hasIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
hasIdentifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
 
hasIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
hasIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
hasIdentifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProtoOrBuilder
 
hasIfOlderThanTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
hasIfOlderThanTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
hasIfOlderThanTs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
 
hasInfoServerPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
hasInfoServerPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
hasInfoServerPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
hasInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
hasInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
hasInMemory() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
hasInterpreterClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
hasInterpreterClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
hasInterpreterClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgumentOrBuilder
 
hasInterpreterSpecificBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
hasInterpreterSpecificBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
hasInterpreterSpecificBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgumentOrBuilder
 
hasIsMasterRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
hasIsMasterRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
hasIsMasterRunning() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponseOrBuilder
 
hasIsShared() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
hasIsShared() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
hasIsShared() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
 
hasIssueDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
hasIssueDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
hasIssueDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
 
hasJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
hasJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
hasJerseyVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
 
hasJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
hasJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
hasJvmVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
 
hasKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
hasKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
hasKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
 
hasKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
hasKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
hasKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
 
hasKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
hasKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
hasKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
 
hasKeyId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
hasKeyId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
hasKeyId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
 
hasKeyType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
hasKeyType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
hasKeyType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValueOrBuilder
 
hasKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
hasKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
hasKind() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
 
hasKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
hasKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
hasKind() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProtoOrBuilder
 
hasLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
hasLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
hasLastDataBlockOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
hasLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
hasLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
hasLastFlushedSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponseOrBuilder
 
hasLastFlushTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
hasLastFlushTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
hasLastFlushTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponseOrBuilder
 
hasLatestVersionOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
hasLatestVersionOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
hasLatestVersionOnly() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
 
hasLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.  
hasLeastSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
hasLeastSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
hasLeastSigBits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUIDOrBuilder
 
hasLenAsVal() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
hasLenAsVal() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
hasLenAsVal() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilterOrBuilder
 
hasLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
hasLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
hasLength() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMetaOrBuilder
 
hasLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
hasLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
hasLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilterOrBuilder
 
hasLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
hasLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
hasLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilterOrBuilder
 
hasLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
hasLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
hasLineNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
 
hasLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
hasLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
hasLoad() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
 
hasLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
hasLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
hasLoadColumnFamiliesOnDemand() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
hasLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
hasLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
hasLoaded() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponseOrBuilder
 
hasLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
hasLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
hasLoaded() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponseOrBuilder
 
hasLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
hasLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
hasLoadOnOpenDataOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
hasLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
hasLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
hasLocation() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
 
hasLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
hasLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
hasLockOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLockOrBuilder
 
hasLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
hasLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
hasLockOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
 
hasLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
hasLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
hasLogSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKeyOrBuilder
 
hasLongMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
hasLongMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
hasLongMsg() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsgOrBuilder
 
hasMajor() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
hasMajor() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
hasMajor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
 
hasMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
hasMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
hasMaster() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
 
hasMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
hasMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
hasMaster() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MasterOrBuilder
 
hasMaster() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Check if there is a master available.
hasMaxColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
hasMaxColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
hasMaxColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
 
hasMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
hasMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
hasMaxColumnInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
 
hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
hasMaxHeapMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
hasMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
hasMaxHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
hasMaxResultSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
hasMaxResultSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
hasMaxResultSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
hasMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
hasMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
hasMaxVersions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
hasMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
hasMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
hasMaxVersions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
hasMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
 
hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
hasMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
hasMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
hasMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
hasMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
 
hasMetaIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
hasMetaIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
hasMetaIndexCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
hasMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
 
hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
hasMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
 
hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
hasMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
 
hasMinColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
hasMinColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
hasMinColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
 
hasMinColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
hasMinColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
hasMinColumnInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
 
hasMoreFanNodes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
hasMoreResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
hasMoreResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
hasMoreResults() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
 
hasMostSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
hasMostSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
hasMostSigBits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUIDOrBuilder
 
hasMutateType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
hasMutateType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
hasMutateType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
hasMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
hasMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
hasMutation() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiActionOrBuilder
 
hasMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
hasMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
hasMutation() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ComparatorOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CoprocessorOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FilterOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPairOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64PairOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPairOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
 
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
hasNext() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
 
hasNext() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
hasNextCallSeq() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
hasNextCallSeq() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
hasNextCallSeq() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
hasNullColumnInQuery() - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
 
hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
hasNumberOfRequests() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasNumberOfRows() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
hasNumberOfRows() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
hasNumberOfRows() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
hasNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
hasNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
hasNumDataIndexLevels() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
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
 
hasOffline() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
hasOffline() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
hasOffline() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
 
hasOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
hasOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
hasOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilterOrBuilder
 
hasOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
hasOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
hasOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequestOrBuilder
 
hasOperator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
hasOperator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
hasOperator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
 
hasOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
hasOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
hasOsVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
 
hasPageSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
hasPageSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
hasPageSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilterOrBuilder
 
hasParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
hasParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
hasParentId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfoOrBuilder
 
hasPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
hasPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
hasPassword() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
 
hasPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
hasPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
hasPassword() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProtoOrBuilder
 
hasPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
hasPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
hasPath() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPathOrBuilder
 
hasPattern() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
hasPattern() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
hasPattern() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
 
hasPatternFlags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
hasPatternFlags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
hasPatternFlags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
 
hasPayload() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
hasPayload() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
hasPayload() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
 
hasPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
hasPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
hasPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequestOrBuilder
 
hasPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
hasPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
hasPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequestOrBuilder
 
hasPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
hasPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
hasPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionOrBuilder
 
hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
hasPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
 
hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
hasPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
 
hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
hasPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
 
hasPosition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
hasPosition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
hasPosition() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPositionOrBuilder
 
hasPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
hasPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
hasPrefix() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilterOrBuilder
 
hasPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
hasPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
hasPrefix() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilterOrBuilder
 
hasPrevBalanceValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
hasPrevBalanceValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
hasPrevBalanceValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponseOrBuilder
 
hasPreviousFanNodes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
hasPrevValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
hasPrevValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
hasPrevValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponseOrBuilder
 
hasProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
hasProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
hasProcessed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponseOrBuilder
 
hasProtocol() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
hasProtocol() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
hasProtocol() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
 
hasPurpose() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
hasPurpose() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
hasPurpose() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
 
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
 
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
 
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
 
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellOrBuilder
 
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValueOrBuilder
 
hasQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
hasRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
hasRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.ReferenceOrBuilder
 
hasReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
hasReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
hasReadOnly() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
 
hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasReadRequestsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasReadRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
hasRealUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
hasRealUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
hasRealUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformationOrBuilder
 
hasReason() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
hasReason() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
hasReason() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequestOrBuilder
 
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.
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequestOrBuilder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequestOrBuilder
 
hasRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
hasRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
hasRegionA() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
 
hasRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
hasRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
hasRegionA() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequestOrBuilder
 
hasRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
hasRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
hasRegionB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
 
hasRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
hasRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
hasRegionB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequestOrBuilder
 
hasRegionId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
hasRegionId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
hasRegionId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
 
hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
hasRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
 
hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
hasRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
 
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
hasRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequestOrBuilder
 
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
hasRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
 
hasRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
hasRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
hasRegions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
hasRegionSpecifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasRegionSpecifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasRegionSpecifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasRegionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
hasRegionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
hasRegionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
 
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
 
hasReportEndTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
hasReportEndTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
hasReportEndTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
hasReportStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
hasReportStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
hasReportStartTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
hasRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
hasRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
hasRequest() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
 
hasRequestParam() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
hasRequestParam() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
hasRequestParam() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
 
hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
hasRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
hasRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
 
hasRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
hasRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
hasRestVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
 
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
hasResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponseOrBuilder
 
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
hasResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponseOrBuilder
 
hasResultSizeBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
hasResultSizeBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
hasResultSizeBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
 
hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
 
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
 
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellOrBuilder
 
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValueOrBuilder
 
hasRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
hasRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
hasRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
 
hasRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
hasRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
hasRowBatchSize() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
 
hasRowProcessorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
hasRowProcessorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
hasRowProcessorClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequestOrBuilder
 
hasRowProcessorInitializerMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
hasRowProcessorInitializerMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
hasRowProcessorInitializerMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequestOrBuilder
 
hasRowProcessorInitializerMessageName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
hasRowProcessorInitializerMessageName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
hasRowProcessorInitializerMessageName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequestOrBuilder
 
hasRowProcessorResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
hasRowProcessorResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
hasRowProcessorResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResultOrBuilder
 
hasRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
hasRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
hasRowsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
 
hasScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
hasScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
hasScan() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
 
hasScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
hasScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
hasScan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgumentOrBuilder
 
hasScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
hasScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
hasScan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
hasScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
hasScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
hasScannerId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
 
hasScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
hasScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
hasScannerId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
 
hasScanResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
hasScanResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
hasScanResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponseOrBuilder
 
hasScopeType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
hasScopeType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
hasScopeType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScopeOrBuilder
 
hasSecond() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
hasSecond() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
hasSecond() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPairOrBuilder
 
hasSecondPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
hasSecondPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
hasSecondPart() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponseOrBuilder
 
hasSelection() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
 
hasSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
hasSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
hasSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
 
hasSerializedComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
hasSerializedComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
hasSerializedComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ComparatorOrBuilder
 
hasSerializedFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
hasSerializedFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
hasSerializedFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FilterOrBuilder
 
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
 
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
 
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder
 
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServerOrBuilder
 
hasServerCurrentTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
hasServerCurrentTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
hasServerCurrentTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
 
hasServerInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
hasServerInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
hasServerInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponseOrBuilder
 
hasServerLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
hasServerLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
hasServerLoad() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
 
hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
hasServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfoOrBuilder
 
hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
hasServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
 
hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
hasServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
 
hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
hasServerStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
 
hasServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
hasServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
hasServerVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
 
hasService() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
hasService() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
hasService() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
 
hasService() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
hasService() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
hasService() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProtoOrBuilder
 
hasServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
hasServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
hasServiceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
 
hasSingleColumnValueFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
hasSingleColumnValueFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
hasSingleColumnValueFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilterOrBuilder
 
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequestOrBuilder
 
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequestOrBuilder
 
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequestOrBuilder
 
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponseOrBuilder
 
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequestOrBuilder
 
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequestOrBuilder
 
hasSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
hasSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
hasSource() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
 
hasSpec() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
hasSpec() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
hasSpec() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
 
hasSplit() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
hasSplit() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
hasSplit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
 
hasSplitkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
hasSplitkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
hasSplitkey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.ReferenceOrBuilder
 
hasSplitPoint() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
hasSplitPoint() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
hasSplitPoint() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequestOrBuilder
 
hasStackTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
hasStackTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
hasStackTrace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
 
hasStamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
hasStamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
hasStamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
 
hasStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
hasStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
hasStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
 
hasStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
hasStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
hasStartCode() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
 
hasStartDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
hasStartDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
hasStartDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUpOrBuilder
 
hasStartKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
hasStartKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
hasStartKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
 
hasStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
hasStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
hasStartKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
 
hasStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
hasStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
hasStartRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
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
 
hasStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
hasStartRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
hasStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
hasStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
hasStartTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
 
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
 
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationStateOrBuilder
 
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
 
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableOrBuilder
 
hasStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
hasStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
hasStopRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
hasStopRowKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
hasStopRowKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
hasStopRowKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilterOrBuilder
 
hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
hasStorefiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasStorefiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasStorefiles() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasStorefiles() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
hasStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
hasStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
hasStoreLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
hasStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
hasStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
hasStoreLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
hasStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
hasStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
hasStoreOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
hasStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
hasStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
hasStoreOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
hasStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasStores() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasStores() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
hasStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasStoreUncompressedSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasSubstr() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
hasSubstr() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
hasSubstr() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparatorOrBuilder
 
hasSynchronous() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
hasSynchronous() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
hasSynchronous() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequestOrBuilder
 
hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
hasTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
 
hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
hasTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequestOrBuilder
 
hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
hasTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
 
hasTable() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKeyOrBuilder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequestOrBuilder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequestOrBuilder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequestOrBuilder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequestOrBuilder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequestOrBuilder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequestOrBuilder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequestOrBuilder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequestOrBuilder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequestOrBuilder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
 
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
hasTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequestOrBuilder
 
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
hasTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequestOrBuilder
 
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
 
hasThreadId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
hasThreadId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
hasThreadId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
 
hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
hasTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
 
hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
hasTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
hasTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
hasTimestamp() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
hasTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
hasTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
hasTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellOrBuilder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
hasTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValueOrBuilder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
hasTimestamp() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
hasTo() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
hasTo() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
hasTo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRangeOrBuilder
 
hasToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
hasToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
hasToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponseOrBuilder
 
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.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
hasTotalNumberOfRequests() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasTotalRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
hasTotalRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
hasTotalRegions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponseOrBuilder
 
hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
hasTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
hasTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
hasTotalUncompressedBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
hasTraceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
hasTraceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
hasTraceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfoOrBuilder
 
hasTraceInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
hasTraceInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
hasTraceInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
 
hasTransitionInZK() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
hasTransitionInZK() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
hasTransitionInZK() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
 
hasTtl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
hasTtl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
hasTtl() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
 
hasTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
hasTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
hasTtl() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
 
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifierOrBuilder
 
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
 
hasUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
hasUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
hasUncompressedDataIndexSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
 
hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
hasUsedHeapMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoadOrBuilder
 
hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionOrBuilder
 
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissionsOrBuilder
 
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
 
hasUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
hasUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
hasUsername() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
 
hasUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
hasUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
hasUsername() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponseOrBuilder
 
hasUserTimestamp() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResultOrBuilder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparableOrBuilder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellOrBuilder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValueOrBuilder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPairOrBuilder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64PairOrBuilder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPairOrBuilder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifierOrBuilder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponseOrBuilder
 
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
 
hasValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
 
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
 
hasValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
 
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContentOrBuilder
 
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
 
hasVersionOfClosingNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
hasVersionOfClosingNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
hasVersionOfClosingNode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
 
hasVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
hasVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
hasVersionOfOfflineNode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
 
hasVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
hasVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
hasVersionsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
 
hasWebuiPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
hasWebuiPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
hasWebuiPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfoOrBuilder
 
hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
hasWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoadOrBuilder
 
hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
hasWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
 
hasWriteTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
hasWriteTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
hasWriteTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKeyOrBuilder
 
hasWriteToWAL() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
hasWriteToWAL() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
hasWriteToWAL() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
 
hasYetToUpdateRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
hasYetToUpdateRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
hasYetToUpdateRegions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponseOrBuilder
 
HBASE_AUTH_TOKEN_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
 
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_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_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client operation timeout, which overrides RPC 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_PREFETCH_LIMIT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for client prefetch limit, used as the maximum number of regions info that will be prefetched.
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_RPC_MAXATTEMPTS - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for maximum attempts, used to limit the number of times the client will try to obtain the proxy for a given region server.
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_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase instance root directory
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_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_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_RPC_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
timeout for each RPC
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_SNAPSHOT_ENABLED - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Enable or disable snapshot support
HBASE_TEMP_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
Temporary directory used for table creation and deletion
HBaseAdmin - Class in org.apache.hadoop.hbase.client
Provides an interface to manage HBase database table metadata + general administrative functions.
HBaseAdmin(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
Constructor.
HBaseAdmin(HConnection) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
Constructor for externally managed HConnections.
HBaseClient - Class in org.apache.hadoop.hbase.ipc
A client for an IPC service.
HBaseClient(Configuration, String, SocketFactory) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseClient
Construct an IPC client whose values are of the Message class.
HBaseClient(Configuration, String) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseClient
Construct an IPC client with the default SocketFactory
HBaseClient.Call - Class in org.apache.hadoop.hbase.ipc
A call waiting for a value.
HBaseClient.Call(Method, Message, CellScanner) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseClient.Call
 
HBaseClient.CallTimeoutException - Exception in org.apache.hadoop.hbase.ipc
Client-side call timeout
HBaseClient.CallTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.HBaseClient.CallTimeoutException
 
HBaseClient.Connection - Class in org.apache.hadoop.hbase.ipc
Thread that reads responses and notifies callers.
HBaseClient.Connection.PingInputStream - Class in org.apache.hadoop.hbase.ipc
This class sends a ping to the remote side when timeout on reading.
HBaseClient.Connection.PingInputStream(InputStream) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseClient.Connection.PingInputStream
 
HBaseClient.ConnectionId - Class in org.apache.hadoop.hbase.ipc
This class holds the address and the user ticket.
HBaseClient.FailedServerException - Exception in org.apache.hadoop.hbase.ipc
 
HBaseClient.FailedServerException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.HBaseClient.FailedServerException
 
HBASECLIENT_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for what hbase client implementation to use.
HBaseClientRPC - Class in org.apache.hadoop.hbase.ipc
An RPC implementation.
HBaseClientRPC() - Constructor for class org.apache.hadoop.hbase.ipc.HBaseClientRPC
 
HBaseConfiguration - Class in org.apache.hadoop.hbase
Adds HBase configuration files to a Configuration
HBaseConfiguration() - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
Deprecated. 
HBaseConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
Deprecated. 
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.
HBaseInfo - Class in org.apache.hadoop.hbase.metrics
Deprecated. 
HBaseInfo() - Constructor for class org.apache.hadoop.hbase.metrics.HBaseInfo
Deprecated.  
HBaseInfo.HBaseInfoMBean - Class in org.apache.hadoop.hbase.metrics
Deprecated.  
HBaseInfo.HBaseInfoMBean(MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.metrics.HBaseInfo.HBaseInfoMBean
Deprecated.  
HBaseIOException - Exception in org.apache.hadoop.hbase.exceptions
All hbase specific IOExceptions should be subclasses of HBaseIOException
HBaseIOException() - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseIOException
 
HBaseIOException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseIOException
 
HBaseIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseIOException
 
HBaseIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseIOException
 
HBaseLocalFileSpanReceiver - Class in org.apache.hadoop.hbase.trace
Wraps the LocalFileSpanReceiver provided in org.cloudera.htrace.impl.LocalFileSpanReceiver to read the file name destination for spans from hbase-site.xml.
HBaseLocalFileSpanReceiver() - Constructor for class org.apache.hadoop.hbase.trace.HBaseLocalFileSpanReceiver
 
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
 
HBaseProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.BigDecimalMsg - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.BigDecimalMsg.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.BigDecimalMsgOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.BytesBytesPair - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.BytesBytesPair.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.BytesBytesPairOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.Cell - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.Cell.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.CellOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.CellType - Enum in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.ColumnFamilySchema - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.ColumnFamilySchema.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.ColumnFamilySchemaOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.CompareType - Enum in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.Coprocessor - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.Coprocessor.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.CoprocessorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.EmptyMsg - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.EmptyMsg.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.EmptyMsgOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.Filter - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.Filter.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.FilterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.KeyValue - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.KeyValue.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.KeyValueOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.LongMsg - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.LongMsg.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.LongMsgOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.NameBytesPair - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.NameBytesPair.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.NameBytesPairOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.NameInt64Pair - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.NameInt64Pair.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.NameInt64PairOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.NameStringPair - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.NameStringPair.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.NameStringPairOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.RegionInfo - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.RegionInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.RegionInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.RegionLoad - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.RegionLoad.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.RegionLoadOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.RegionSpecifier - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.RegionSpecifier.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.RegionSpecifier.RegionSpecifierType - Enum in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.RegionSpecifierOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.ServerLoad - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.ServerLoad.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.ServerLoadOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.ServerName - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.ServerName.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.ServerNameOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.SnapshotDescription - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.SnapshotDescription.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.SnapshotDescription.Type - Enum in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.SnapshotDescriptionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.TableSchema - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.TableSchema.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.TableSchemaOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.TimeRange - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.TimeRange.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.TimeRangeOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
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) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
Create a HBaseSaslRpcClient for an authentication method
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.QualityOfProtection - Enum in org.apache.hadoop.hbase.security
 
HBaseSaslRpcServer.SaslDigestCallbackHandler - Class in org.apache.hadoop.hbase.security
CallbackHandler for SASL DIGEST-MD5 mechanism
HBaseSaslRpcServer.SaslDigestCallbackHandler(SecretManager<TokenIdentifier>, HBaseServer.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
 
HBaseServer - Class in org.apache.hadoop.hbase.ipc
A client for an IPC service.
HBaseServer(String, int, int, int, Configuration, String, int) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseServer
 
HBaseServer.Call - Class in org.apache.hadoop.hbase.ipc
A call queued for handling.
HBaseServer.Call(int, Method, Message, CellScanner, HBaseServer.Connection, HBaseServer.Responder, long, TraceInfo) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
HBaseServer.CallQueueTooBigException - Exception in org.apache.hadoop.hbase.ipc
 
HBaseServer.Connection - Class in org.apache.hadoop.hbase.ipc
Reads calls from a connection and queues them for handling.
HBaseServer.Connection(SocketChannel, long) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
 
HBaseServer.Responder - Class in org.apache.hadoop.hbase.ipc
 
HBaseServerRPC - Class in org.apache.hadoop.hbase.ipc
A simple RPC mechanism.
HBaseSnapshotException - Exception in org.apache.hadoop.hbase.exceptions
General exception base class for when a snapshot fails
HBaseSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.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.exceptions.HBaseSnapshotException
Exception for the given snapshot that has no previous root cause
HBaseSnapshotException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseSnapshotException
Exception for the given snapshot due to another exception
HBaseSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseSnapshotException
Exception when the description of the snapshot cannot be determined, due to some root other root cause
HBASEVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
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
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. 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. 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. use HColumnDescriptor.HColumnDescriptor(String) and setters
HColumnDescriptor(byte[], int, int, boolean, String, boolean, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated. use HColumnDescriptor.HColumnDescriptor(String) and setters
HConnection - Interface in org.apache.hadoop.hbase.client
Cluster connection.
HConnectionManager - Class in org.apache.hadoop.hbase.client
A non-instantiable class that manages HConnections.
HConnectionManager() - Constructor for class org.apache.hadoop.hbase.client.HConnectionManager
 
HConnectionManager.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.
HConnectionManager.HConnectable(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HConnectionManager.HConnectable
 
HConnectionManager.HConnectionKey - Class in org.apache.hadoop.hbase.client
Denotes a unique key to a HConnection instance.
HConnectionManager.HConnectionKey(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionKey
 
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 amount 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
 
headerSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Returns the size of this block header.
headMap(K) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
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.StoreScanner
 
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.CachedBlock
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlockQueue
Total size of all elements in this queue.
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
 
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.LruBlockCache
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
 
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.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.MemStore
Get the entire heap usage for this MemStore not including keys in the snapshot.
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
HEAPSIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
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.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_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
Reading HFile version 1 and 2 blocks, and writing version 2 blocks.
HFileBlock.BlockIterator - Interface in org.apache.hadoop.hbase.io.hfile
An interface allowing to iterate HFileBlocks.
HFileBlock.BlockWritable - Interface in org.apache.hadoop.hbase.io.hfile
Something that can be written into a block.
HFileBlock.FSReader - Interface in org.apache.hadoop.hbase.io.hfile
A full-fledged reader with iteration ability.
HFileBlock.Writer - Class in org.apache.hadoop.hbase.io.hfile
Unified version 2 HFile block writer.
HFileBlock.Writer(Compression.Algorithm, HFileDataBlockEncoder, boolean, ChecksumType, int) - 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(Compression.Algorithm) - 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(Compression.Algorithm, DataBlockEncoding, byte[]) - 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 (HFileBlockIndex.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(RawComparator<byte[]>, int, HFile.CachingBlockReader) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
HFileBlockIndex.BlockIndexReader(RawComparator<byte[]>, 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, BlockCache, 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) - Constructor for class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
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
 
HFileDataBlockEncoderImpl(DataBlockEncoding, DataBlockEncoding) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
Do data block encoding with specified options.
HFileDataBlockEncoderImpl(DataBlockEncoding, DataBlockEncoding, byte[]) - 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(Configuration, Path) - Constructor for class org.apache.hadoop.hbase.io.HFileLink
 
HFileLink(Path, Path, Path) - Constructor for class org.apache.hadoop.hbase.io.HFileLink
 
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
Writes HFiles.
HFileOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
 
hfilePattern - Static variable in class org.apache.hadoop.hbase.util.FSUtils.HFileFilter
 
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
 
HFileProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
HFileProtos.FileInfoProto - Class in org.apache.hadoop.hbase.protobuf.generated
 
HFileProtos.FileInfoProto.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HFileProtos.FileInfoProtoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HFileProtos.FileTrailerProto - Class in org.apache.hadoop.hbase.protobuf.generated
 
HFileProtos.FileTrailerProto.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
HFileProtos.FileTrailerProtoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HFileReaderV2 - Class in org.apache.hadoop.hbase.io.hfile
HFile reader for version 2.
HFileReaderV2(Path, FixedFileTrailer, FSDataInputStream, FSDataInputStream, long, boolean, CacheConfig, DataBlockEncoding, HFileSystem) - 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, boolean) - 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
 
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.
HFileWriterV2 - Class in org.apache.hadoop.hbase.io.hfile
Writes HFile format version 2.
HFileWriterV2(Configuration, CacheConfig, FileSystem, Path, FSDataOutputStream, int, Compression.Algorithm, HFileDataBlockEncoder, KeyValue.KeyComparator, ChecksumType, int, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Constructor that takes a path, creates and closes the output stream.
hflush() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
 
hfs - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
The filesystem used for accesing data
HIGH_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
highPriorityLevel - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
hint - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
hit(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
hlog - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
HLog - Interface in org.apache.hadoop.hbase.regionserver.wal
 
HLog.Entry - Class in org.apache.hadoop.hbase.regionserver.wal
Utility class that lets us keep track of the edit with it's key Only used when splitting logs
HLog.Entry() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLog.Entry
 
HLog.Entry(HLogKey, WALEdit) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLog.Entry
Constructor for both params
HLog.Reader - Interface in org.apache.hadoop.hbase.regionserver.wal
 
HLog.Writer - Interface in org.apache.hadoop.hbase.regionserver.wal
 
HLogFactory - Class in org.apache.hadoop.hbase.regionserver.wal
 
HLogFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogFactory
 
hlogForMeta - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
HLogInputFormat - Class in org.apache.hadoop.hbase.mapreduce
Simple InputFormat for HLog files.
HLogInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
 
HLogKey - Class in org.apache.hadoop.hbase.regionserver.wal
A Key for an entry in the change log.
HLogKey() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Writable Constructor -- Do not use.
HLogKey(byte[], byte[], long, long, UUID) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Create the log key! We maintain the tablename mainly for debugging purposes.
HLogLink - Class in org.apache.hadoop.hbase.io
HLogLink describes a link to a WAL.
HLogLink(Configuration, String, String) - Constructor for class org.apache.hadoop.hbase.io.HLogLink
 
HLogLink(Path, String, String) - Constructor for class org.apache.hadoop.hbase.io.HLogLink
 
HLogLink(Path, Path) - Constructor for class org.apache.hadoop.hbase.io.HLogLink
 
HLogPrettyPrinter - Class in org.apache.hadoop.hbase.regionserver.wal
HLogPrettyPrinter prints the contents of a given HLog with a variety of options affecting formatting and extent of content.
HLogPrettyPrinter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
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
Fully specified constructor.
HLogSplitter - Class in org.apache.hadoop.hbase.regionserver.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.
HLogSplitter(Configuration, Path, Path, Path, FileSystem, LastSequenceId) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
 
HLogUtil - Class in org.apache.hadoop.hbase.regionserver.wal
 
HLogUtil() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogUtil
 
HMaster - Class in org.apache.hadoop.hbase.master
HMaster is the "master server" for HBase.
HMaster(Configuration) - Constructor for class org.apache.hadoop.hbase.master.HMaster
Initializes the HMaster.
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) - Constructor for class org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
 
host - Static variable in class org.apache.hadoop.hbase.thrift.DemoClient
 
hostAddress - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
 
HOSTNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
HOSTNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
HOSTNAME_PORT_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Addressing
 
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 stores data for a certain region of a table.
HRegion(Path, HLog, FileSystem, Configuration, HRegionInfo, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
Deprecated. 
HRegion(HRegionFileSystem, HLog, Configuration, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
HRegion constructor.
HRegion.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
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 Use '.' as a special character to seperate the log files from table data
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_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key for the memstore size at which we flush the memstore
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
HRegionFileSystem - Class in org.apache.hadoop.hbase.regionserver
View to an on-disk Region.
HRegionInfo - Class in org.apache.hadoop.hbase
HRegion information.
HRegionInfo() - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Deprecated. Used by Writables and Writables are going away.
HRegionInfo(byte[]) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
 
HRegionInfo(byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(byte[], byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(byte[], byte[], byte[], boolean, long) - 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
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
 
HRegionPartitioner<K2,V2> - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapred.HRegionPartitioner
Deprecated.  
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.MovedRegionsCleaner - Class in org.apache.hadoop.hbase.regionserver
Creates a Chore thread to clean the moved region cache.
HRegionServer.QosPriority - Annotation Type in org.apache.hadoop.hbase.regionserver
 
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
 
HRegionThriftServer - Class in org.apache.hadoop.hbase.regionserver
HRegionThriftServer - this class starts up a Thrift server in the same JVM where the RegionServer is running.
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
hsync() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
 
HTable - Class in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table.
HTable(Configuration, String) - Constructor for class org.apache.hadoop.hbase.client.HTable
Creates an object to access a HBase table.
HTable(Configuration, byte[]) - Constructor for class org.apache.hadoop.hbase.client.HTable
Creates an object to access a HBase table.
HTable(Configuration, byte[], ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Creates an object to access a HBase table.
HTable(byte[], HConnection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Creates an object to access a HBase table.
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 .META.
HTableDescriptor(byte[], HColumnDescriptor[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Private constructor used internally creating table descriptors for catalog tables, .META. and -ROOT-.
HTableDescriptor(byte[], HColumnDescriptor[], Map<ImmutableBytesWritable, ImmutableBytesWritable>) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Private constructor used internally creating table descriptors for catalog tables, .META. and -ROOT-.
HTableDescriptor() - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated. Used by Writables and Writables are going away.
HTableDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor specifying table name.
HTableDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor specifying a byte array table name
HTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor by cloning the descriptor passed as a parameter.
hTableDescriptor - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
 
HTableFactory - Class in org.apache.hadoop.hbase.client
Factory for creating HTable instances.
HTableFactory() - Constructor for class org.apache.hadoop.hbase.client.HTableFactory
 
HTableInterface - Interface in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table.
HTableInterfaceFactory - Interface in org.apache.hadoop.hbase.client
Defines methods to create new HTableInterface.
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
 
HTablePool - Class in org.apache.hadoop.hbase.client
A simple pool of HTable instances.
HTablePool() - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Default Constructor.
HTablePool(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Constructor to set maximum versions and use the specified configuration.
HTablePool(Configuration, int, HTableInterfaceFactory) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
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
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
Constructor to set maximum versions and use the specified configuration, table factory and pool type.
HTableUtil - Class in org.apache.hadoop.hbase.client
Utility class for HTable.
HTableUtil() - Constructor for class org.apache.hadoop.hbase.client.HTableUtil
 
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
 
humanReadableTimestamp(long) - Static method in class org.apache.hadoop.hbase.KeyValue
 

I

I - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'I'
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.codec.prefixtree.encode.tokenize.TokenizerNode
 
id - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
ID_ATRIBUTE - Static variable in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
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).
IDENTIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
IDENTIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
IdentityTableMap - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
IdentityTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableMap
Deprecated. 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
Deprecated. 
IdentityTableReduce() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableReduce
Deprecated.  
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
 
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
IFOLDERTHANTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
ignoreZKDeleteForTesting - Variable in class org.apache.hadoop.hbase.master.SplitLogManager
 
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
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(byte[], 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(byte[], 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
 
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 - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HConstants
 
inc(int) - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
Deprecated.  
inc() - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
Deprecated.  
inc(int, long) - Method in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
Deprecated. Increment the metrics for numOps operations
inc(long) - Method in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
Deprecated. Increment the metrics for numOps operations
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
 
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.
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.
INCLUDE_FULL_TREE_IN_TO_STRING - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
print/debug
includeMVCCReadpoint - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
includeMVCCReadpoint(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
includeMVCCReadpoint(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
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
 
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.
includesMvccVersion - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
includesTimeRange(TimeRange) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
Check if the range has any overlap with TimeRange
includeTable(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
includeTimestamp(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
Update the current TimestampRange to include the timestamp from KeyValue If the Key is of type DeleteColumn or DeleteFamily, it includes the entire time range from 0 to timestamp of the key.
includeTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
Update the current TimestampRange to include the timestamp from Key.
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
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, squared, times 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(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 interface org.apache.hadoop.hbase.client.HTableInterface
Increments one or more columns within a single row.
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(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
increment() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
Increment the current version count
increment(Increment, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Perform one or more increment operations on a row.
increment(HRegion, ClientProtos.MutationProto, CellScanner) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Execute an increment mutation.
increment(Increment) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
increment(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
increment(ByteBuffer, TIncrement, AsyncMethodCallback<THBaseService.AsyncClient.increment_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
increment(ByteBuffer, TIncrement, AsyncMethodCallback<THBaseService.AsyncClient.increment_call>) - 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 - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
the TIncrement to increment
increment(ByteBuffer, TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
INCREMENT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
 
incrementAppendCount() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Increment the count of hlog 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.TsvImporterMapper
 
incrementBlocks() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
Increments the number of blocks in the cache for this entry
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
Atomically increments a column value.
incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
Atomically increments a column value.
incrementColumnValue(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Atomically increments a column value.
incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
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, boolean) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
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
 
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
 
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
 
incrementHeapSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
 
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
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(int) - 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
 
incrementRows(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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
 
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
 
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
 
incrementSyncTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Add the time it took to sync the hlog.
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
incRequests(int) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
Increment the number of requests the cluster has seen.
incRequests(int) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
 
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.
incRpcCount() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
 
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
 
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
 
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.
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
 
inferBoundaries(TreeMap<byte[], Integer>) - Static method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
InfoServer - Class in org.apache.hadoop.hbase.util
Create a Jetty embedded server to answer http requests.
InfoServer(String, String, int, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.util.InfoServer
Create a status server on the given port.
INFOSERVERPORT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
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.master.MetricsMasterSourceImpl
 
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(String, ContextFactory) - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
Deprecated.  
init() - Static method in class org.apache.hadoop.hbase.metrics.HBaseInfo
Deprecated.  
init() - Method in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
Deprecated.  
init(FileSystem, Path, Configuration) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Reader
 
init(FileSystem, Path, Configuration) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Writer
 
init(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
init(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
 
init(Configuration, FileSystem, ReplicationSourceManager, Stoppable, AtomicBoolean, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
Instantiation method used by region servers
init(Configuration, FileSystem, ReplicationSourceManager, Stoppable, AtomicBoolean, String) - 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 hlog queues
init(FilterConfig) - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
 
init() - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
 
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() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
initCredentials(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated.  
initCredentials(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
 
initFirstNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
initialChore() - Method in class org.apache.hadoop.hbase.Chore
Override to run a task before we start looping.
initialChore() - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
 
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.LongColumnInterpreter
 
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(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() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Deprecated. use HRegion.createHRegion() or HRegion.openHRegion()
initialize(long) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
Initializes the memstoreRead/Write points appropriately.
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(Server, FileSystem, Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
initializeWriter(List<RowNodeWriter>, int, TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
initJob(String, String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Deprecated. Use this before submitting a TableMap job.
initJob(String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
Deprecated. 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.
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
 
initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated. 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
Deprecated. 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(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(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<? extends WritableComparable>, Class<? extends Writable>, 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<? extends WritableComparable>, Class<? extends Writable>, Job, 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
Deprecated. Use this before submitting a TableReduce job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated. 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
Deprecated. 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.
injectEdge(EnvironmentEdge) - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
Injects the given edge such that it becomes the managed entity.
InlineBlockWriter - Interface in org.apache.hadoop.hbase.io.hfile
A way to write "inline" blocks into an HFile.
INMEMORY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
 
INPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Job parameter that specifies the input table.
insertNewFile(StoreFile) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Adds new file, either for from MemStore flush or bulk insert, into the structure.
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.
INSTANCE - Static variable in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
instance - Static variable in class org.apache.hadoop.hbase.zookeeper.EmptyWatcher
 
instantiateHLog(Path, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Called by HRegionServer.setupWALAndReplication() creating WAL instance.
instantiateHStore(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
instantiateRegionScanner(Scan, List<KeyValueScanner>) - 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
internalEncodeKeyValues(DataOutputStream, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
internalEncodeKeyValues(DataOutputStream, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
 
internalEncodeKeyValues(DataOutputStream, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
 
internalEncodeKeyValues(DataOutputStream, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
 
internalFlushcache(MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Flush the memstore.
internalFlushcache(HLog, long, MonitoredTask) - 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.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.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
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.ScopeType
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
 
internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
 
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.
INTERPRETERCLASSNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
INTERPRETERSPECIFICBYTES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
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.util.HasThread
 
interruptedException(InterruptedException) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Handles InterruptedExceptions in client calls.
intervalHeartBeat() - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
Deprecated.  
intFitsIn(int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Check how many bytes is required to store value.
INVALID_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
Constant to denote invalid hash type.
InvalidFamilyOperationException - Exception in org.apache.hadoop.hbase.exceptions
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.exceptions.InvalidFamilyOperationException
default constructor
InvalidFamilyOperationException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.InvalidFamilyOperationException
Constructor
InvalidFamilyOperationException(Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.InvalidFamilyOperationException
Constructor taking another exception.
InvalidHFileException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when an invalid HFile format is detected
InvalidHFileException() - Constructor for exception org.apache.hadoop.hbase.exceptions.InvalidHFileException
constructor
InvalidHFileException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.InvalidHFileException
Constructor
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
invoke(Object, Method, Object[]) - Method in class org.apache.hadoop.hbase.thrift.HbaseHandlerMetricsProxy
 
io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_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.get_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.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.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 could support data services for BucketCache.
ioHit(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
 
IpcProtocol - Interface in org.apache.hadoop.hbase
Marker Interface used by ipc.
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 .META.
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 class org.apache.hadoop.hbase.client.HBaseAdmin
 
isAborted() - Method in class org.apache.hadoop.hbase.master.HMaster
 
isAborted() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
isAborted() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
 
isAborted() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
 
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
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.util.HasThread
 
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
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()
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
Tells whether or not 'auto-flush' is turned on.
isAutoFlush() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
isAvailable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
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.
isBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
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
 
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.
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
 
isCanceled() - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
isCanceled() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
isCarryingMeta(ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
isCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Query on the catalog janitor state (Enabled/Disabled?)
isCatalogJanitorEnabled(RpcController, MasterAdminProtos.IsCatalogJanitorEnabledRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
isCatalogJanitorEnabled(RpcController, MasterAdminProtos.IsCatalogJanitorEnabledRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
isCatalogJanitorEnabled(RpcController, MasterAdminProtos.IsCatalogJanitorEnabledRequest, RpcCallback<MasterAdminProtos.IsCatalogJanitorEnabledResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
isCatalogJanitorEnabled(RpcController, MasterAdminProtos.IsCatalogJanitorEnabledRequest, RpcCallback<MasterAdminProtos.IsCatalogJanitorEnabledResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
isCatalogJanitorEnabled(RpcController, MasterAdminProtos.IsCatalogJanitorEnabledRequest, RpcCallback<MasterAdminProtos.IsCatalogJanitorEnabledResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
isChildWriteLock(String) - Static method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Check if a child znode represents a write lock.
isClassExempt(String) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorClassLoader
Determines whether the given class should be exempt from being loaded by this ClassLoader.
isClosed() - Method in interface org.apache.hadoop.hbase.client.HConnection
 
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
 
isClosing() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isClosing() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
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.
isCompaction - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
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
Create a KeyValue reading from the raw InputStream.
isData() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
 
isDeadServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
 
isDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
 
isDeferredLogFlush() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Check if deferred log edits are enabled on the table.
isDelayed() - Method in interface org.apache.hadoop.hbase.ipc.Delayable
 
isDelayed() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
isDelete(byte) - Static method in class org.apache.hadoop.hbase.KeyValue
 
isDelete() - Method in class org.apache.hadoop.hbase.KeyValue
 
isDeleteColumnOrFamily() - Method in class org.apache.hadoop.hbase.KeyValue
 
isDeleted(byte[], int, int, long) - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
Check if the specified KeyValue buffer has been deleted by a previously seen delete.
isDeleted(byte[], int, int, long) - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
Check if the specified KeyValue buffer has been deleted by a previously seen delete.
isDeleteFamily() - Method in class org.apache.hadoop.hbase.KeyValue
 
isDeleteFamilyBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
 
isDeleteType() - Method in class org.apache.hadoop.hbase.KeyValue
 
isDirectlyAfterNub() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayReversibleScanner
 
isDisabledOrEnablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
 
isDisabledTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
 
isDisabledTable(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLED.
isDisablingOrDisabledTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
 
isDisablingOrDisabledTable(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLING of ZooKeeperProtos.Table.State#DISABLED.
isDisablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
 
isDone(long) - Method in interface org.apache.hadoop.hbase.regionserver.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.ExplicitColumnTracker
 
isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
 
isDone(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isDone() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
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 KeyValue [] is empty or not
isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
isEmpty() - Method in class org.apache.hadoop.hbase.master.DeadServer
 
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.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(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 class org.apache.hadoop.hbase.util.ByteRange
 
isEmpty(ByteRange) - Static method in class org.apache.hadoop.hbase.util.ByteRange
static methods
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.SoftValueSortedMap
 
isEmpty() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
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.  
isEmptyColumn() - Method in class org.apache.hadoop.hbase.KeyValue
 
isEnabledOrDisablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
 
isEnabledTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
 
isEnabledTable(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#ENABLED.
isEnablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
 
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.HBaseServer.Call
 
isExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Calls fs.exists().
isFailedClose() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isFailedOpen() - Method in class org.apache.hadoop.hbase.master.RegionState
 
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.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
 
isFileDeletable(Path) - Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
 
isFileDeletable(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseLogCleanerDelegate
 
isFileDeletable(Path) - Method in interface org.apache.hadoop.hbase.master.cleaner.FileCleanerDelegate
Should the master delete the file or keep it?
isFileDeletable(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
 
isFileDeletable(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
 
isFileDeletable(Path) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
 
isFileDeletable(Path) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
 
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.
isFirstCellInRow() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
isFullServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
isGeneralBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
 
isGet - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
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.security.access.AccessControlLists
Returns whether or not the given name should be interpreted as a group principal.
isGZIPOutputStreamFinishBroken() - Static method in class org.apache.hadoop.hbase.util.JVM
Check if the finish() method of GZIPOutputStream is broken
isHBaseSecurityEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.security.User
Returns whether or not secure authentication is enabled for HBase.
isHDFS(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
isHFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isHFile(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isHFileLink(Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
 
isHFileLink(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
 
isIncludesMvccVersion() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
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 class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.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
 
isInMemory() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isInMemory() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
isInRequest() - Method in class org.apache.hadoop.hbase.ipc.RequestContext
 
isInRequestContext() - Static method in class org.apache.hadoop.hbase.ipc.RequestContext
Indicates whether or not the current thread is within scope of executing an RPC request.
isInternal() - Method in class org.apache.hadoop.hbase.KeyValue
 
isInterrupted() - Method in class org.apache.hadoop.hbase.util.HasThread
 
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
 
isLegalFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
 
isLegalTableName(byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
Check passed byte buffer, "tableName", is legal user-space table name.
isLink() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isLoadingCfsOnDemandDefault() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isLocal(Configuration) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
isLocationAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
Checks if the meta region location is available.
isLogDeletable(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseLogCleanerDelegate
Deprecated. 
isLogDeletable(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
 
isLogDeletable(Path) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
 
isLowReplicationRollEnabled() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
Get LowReplication-Roller status
isMajor() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
isMajorCompacted(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Runs through the hbase rootdir and checks all stores have only one file in them -- that is, they've been major compacted.
isMajorCompactedPre020(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Runs through the hbase rootdir and checks all stores have only one file in them -- that is, they've been major compacted.
isMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
 
isMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactionPolicy
 
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
 
isMaster() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
isMasterRunning() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.HConnection
 
isMasterRunning() - Method in class org.apache.hadoop.hbase.master.HMaster
 
isMasterRunning(RpcController, MasterProtos.IsMasterRunningRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
isMasterRunning(RpcController, MasterProtos.IsMasterRunningRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
 
isMasterRunning(RpcController, MasterProtos.IsMasterRunningRequest, RpcCallback<MasterProtos.IsMasterRunningResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
 
isMasterRunning(RpcController, MasterProtos.IsMasterRunningRequest, RpcCallback<MasterProtos.IsMasterRunningResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
 
isMasterRunning(RpcController, MasterProtos.IsMasterRunningRequest, RpcCallback<MasterProtos.IsMasterRunningResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
 
ISMASTERRUNNING_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
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
 
isMetaFamily(byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogUtil
 
isMetaFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogUtil
 
isMetaRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isMetaRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Checks if this table is either -ROOT- or .META.
isMetaTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isMetaTable() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Checks if the table is a .META. table
isMetaTable(byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
Checks of the tableName being passed represents either -ROOT- or .META.
isMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
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
 
isOffline() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isOffPeak() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
IsolationLevel - Enum in org.apache.hadoop.hbase.client
Specify Isolation levels in Scan operations.
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.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.get
 
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.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.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 - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
isOnline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Report the status of the server.
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
 
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.
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
 
isParallelSeekEnabled - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
A flag that enables StoreFileScanner parallel-seeking
isPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
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.ReplicationZookeeper
Determine if a ZK path points to a peer node.
isPendingClose() - 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
 
isPendingOpenOrOpeningOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
 
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
 
isPre020FileLayout(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Expects to find -ROOT- directory.
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
 
isReadOnly() - Method in class org.apache.hadoop.hbase.HTableDescriptor
Check if the readOnly flag of the table is set.
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
 
isRegionAssigned(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
isRegionFailedToClose(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
 
isRegionFailedToOpen(HRegionInfo) - 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
 
isRegionsInTransition() - Method in class org.apache.hadoop.hbase.master.RegionStates
 
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.
isReplication(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
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
 
isRestoreSnapshotDone(RpcController, MasterAdminProtos.IsRestoreSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
Returns the status of the requested snapshot restore/clone operation.
isRestoreSnapshotDone(RpcController, MasterAdminProtos.IsRestoreSnapshotDoneRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
isRestoreSnapshotDone(RpcController, MasterAdminProtos.IsRestoreSnapshotDoneRequest, RpcCallback<MasterAdminProtos.IsRestoreSnapshotDoneResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
isRestoreSnapshotDone(RpcController, MasterAdminProtos.IsRestoreSnapshotDoneRequest, RpcCallback<MasterAdminProtos.IsRestoreSnapshotDoneResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
isRestoreSnapshotDone(RpcController, MasterAdminProtos.IsRestoreSnapshotDoneRequest, RpcCallback<MasterAdminProtos.IsRestoreSnapshotDoneResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
isRestoringTable(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Returns status of a restore request, specifically comparing source snapshot and target table names.
isReturnResults() - Method in class org.apache.hadoop.hbase.client.Append
 
isReturnValueDelayed() - Method in interface org.apache.hadoop.hbase.ipc.Delayable
 
isReturnValueDelayed() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
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.
isSameHostnameAndPort(ServerName, ServerName) - Static method in class org.apache.hadoop.hbase.ServerName
 
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.
isSecurityEnabled - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
isSecurityEnabled() - Static method in class org.apache.hadoop.hbase.security.User
Returns whether or not Kerberos authentication is configured for Hadoop.
isSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
isSeeked() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
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
 
isServerShutdownHandlerEnabled() - Method in class org.apache.hadoop.hbase.master.HMaster
ServerShutdownHandlerEnabled is set false before completing assignMeta to prevent processing of ServerShutdownHandler.
isServerShutdownHandlerEnabled() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
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.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.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.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.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.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.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(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(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(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
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
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
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
isSetDeletes() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
Returns true if field deletes is set (has been assigned a value) and false otherwise
isSetDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
Returns true if field deleteSingle is set (has been assigned a value) and false otherwise
isSetDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
Returns true if field deleteSingle is set (has been assigned a value) and false otherwise
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
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.checkAndPut_args
Returns true if field family is set (has been assigned a value) and false otherwise
isSetGet() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
Returns true if field get is set (has been assigned a value) and false otherwise
isSetGet() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
Returns true if field get is set (has been assigned a value) and false otherwise
isSetGets() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
Returns true if field gets 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
isSetIncrement() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
Returns true if field increment 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.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.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.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.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.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
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.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.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
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
isSetPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
Returns true if field put is set (has been assigned a value) and false otherwise
isSetPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
Returns true if field put is set (has been assigned a value) and false otherwise
isSetPuts() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
Returns true if field puts is set (has been assigned a value) and false otherwise
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.checkAndPut_args
Returns true if field qualifier 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.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.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
isSetScan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_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
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.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.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.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.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.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.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.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.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.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.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.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.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
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.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
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.checkAndPut_args
Returns true if field value is set (has been assigned a value) and false otherwise
isSetWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
Returns true if field writeToWal is set (has been assigned a value) and false otherwise
isSetWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
Returns true if field writeToWal is set (has been assigned a value) and false otherwise
isSetWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
Returns true if field writeToWal is set (has been assigned a value) and false otherwise
ISSHARED_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
isShowConfInServlet() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
 
isSingleRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
isSkipChecks() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
isSlaveDown() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
Check if the slave is down by trying to establish a connection
isSnapshotDone(RpcController, MasterAdminProtos.IsSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
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
isSnapshotDone(RpcController, MasterAdminProtos.IsSnapshotDoneRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
isSnapshotDone(RpcController, MasterAdminProtos.IsSnapshotDoneRequest, RpcCallback<MasterAdminProtos.IsSnapshotDoneResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
isSnapshotDone(RpcController, MasterAdminProtos.IsSnapshotDoneRequest, RpcCallback<MasterAdminProtos.IsSnapshotDoneResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
isSnapshotDone(RpcController, MasterAdminProtos.IsSnapshotDoneRequest, RpcCallback<MasterAdminProtos.IsSnapshotDoneResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
isSnapshotFinished(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Check the current state of the passed snapshot.
isSorted(Collection<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
isSplit() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isSplit() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isSplitParent() - Method in class org.apache.hadoop.hbase.HRegionInfo
 
isSplittable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isSplitting() - Method in class org.apache.hadoop.hbase.master.RegionState
 
isStartingWithPath(Path, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Compare of path component.
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.HMaster
 
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.SnapshotLogCleaner
 
isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
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.replication.master.ReplicationLogCleaner
 
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
 
isSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_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
 
ISSUEDATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableAvailable(String, 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
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[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
 
isTableAvailable(byte[], byte[][]) - Method in interface org.apache.hadoop.hbase.client.HConnection
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(String) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
isTableDisabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableDisabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableDisabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
 
isTableEnabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
isTableEnabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
A table that isTableEnabled == false and isTableDisabled == false is possible.
isTableEnabled(String) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated. use HBaseAdmin.isTableEnabled(byte[])
isTableEnabled(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated. use HBaseAdmin.isTableEnabled(byte[])
isTableEnabled(Configuration, String) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated. use HBaseAdmin.isTableEnabled(byte[])
isTableEnabled(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
Deprecated. use HBaseAdmin.isTableEnabled(byte[] tableName)
isTableEnabled(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
isTableInfoExists(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Checks if .tableinfo exists for given table
isTablePresent(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
check if table is present .
isTaskPath(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
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
 
istream - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Stream to read from.
istreamNoFsChecksum - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
The file system stream of the underlying HFile that does not do checksum verification in the file system
isUnassigned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isUnassigned() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isUnix() - Static method in class org.apache.hadoop.hbase.util.JVM
Check if the OS is unix.
isValid(FileStatus) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Return if the specified file is a valid store file or not.
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
 
isWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
isWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
isWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
isWriting() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
 
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 class org.apache.hadoop.hbase.thrift.CallQueue
 
iterator() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
iterator() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 

J

jarDir(File, String, ZipOutputStream) - Static method in class org.apache.hadoop.hbase.mapreduce.hadoopbackport.JarFinder
 
JarFinder - Class in org.apache.hadoop.hbase.mapreduce.hadoopbackport
Finds the Jar for a class.
JarFinder() - Constructor for class org.apache.hadoop.hbase.mapreduce.hadoopbackport.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
 
JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
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.ipc.HBaseServer
Wait for the server to be stopped.
join() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
 
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.regionserver.HRegionServer
Wait on all threads to finish.
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.
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
 
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
 
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
KerberosInfo - Annotation Type in org.apache.hadoop.hbase.security
Indicates Kerberos related information to be used for authorizing connections over a given RPC protocol interface.
key - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The key
KEY_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
Comparator for plain key; i.e.
KEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
KEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
KEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
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_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
Size of the key length field in bytes
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
keyClass - Variable in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
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
 
KEYID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
Keying - Class in org.apache.hadoop.hbase.util
Utility creating hbase friendly keys.
Keying() - Constructor for class org.apache.hadoop.hbase.util.Keying
 
keyLength(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
KeyLocker<K extends Comparable<? super 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
 
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
 
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
 
KeyRange - Interface in org.apache.hadoop.hbase.util
A key range use in split coverage.
keySet() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
keySet() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
keySet() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
keySize() - Method in class org.apache.hadoop.hbase.regionserver.MemStore
Get the heap usage of KVs in this MemStore.
keyToString(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
 
keyToString(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
 
keyToUri(String) - Static method in class org.apache.hadoop.hbase.util.Keying
Reverse the Keying.createKey(String) transform.
KEYTYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
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, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue from the specified byte array, starting at offset, for length length, and a known keyLength.
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 filled with null value.
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, KeyValue.Type, 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) - 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) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
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(byte[], 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) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue.KeyComparator - Class in org.apache.hadoop.hbase
Compare key portion of a KeyValue.
KeyValue.KeyComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.KeyComparator
 
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 .META. catalog table KeyValues.
KeyValue.MetaComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.MetaComparator
 
KeyValue.MetaKeyComparator - Class in org.apache.hadoop.hbase
Compare key portion of a KeyValue for keys in .META. table.
KeyValue.MetaKeyComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.MetaKeyComparator
 
KeyValue.RootComparator - Class in org.apache.hadoop.hbase
A KeyValue.KVComparator for -ROOT- catalog table KeyValues.
KeyValue.RootComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.RootComparator
 
KeyValue.RootKeyComparator - Class in org.apache.hadoop.hbase
Compare key portion of a KeyValue for keys in -ROOT- table.
KeyValue.RootKeyComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.RootKeyComparator
 
KeyValue.RowComparator - Class in org.apache.hadoop.hbase
Comparator that compares row component only of a KeyValue.
KeyValue.RowComparator(KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.KeyValue.RowComparator
 
KeyValue.SamePrefixComparator<T> - Interface in org.apache.hadoop.hbase
Avoids redundant comparisons for better performance.
KeyValue.SplitKeyValue - Class in org.apache.hadoop.hbase
Utility class that splits a KeyValue buffer into separate byte arrays.
KeyValue.Type - Enum in org.apache.hadoop.hbase
Key type.
KEYVALUE_INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
 
KEYVALUEBYTES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
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
 
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.
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
 
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
KIND_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
KIND_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
kvGenerator - Variable in class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
 

L

L - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'L'
last() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
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
lastActivity - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
LASTDATABLOCKOFFSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
LASTFLUSHEDSEQUENCEID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
LASTFLUSHTIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
lastHost - Variable in class org.apache.hadoop.hbase.rest.client.Cluster
 
lastKey - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Last key in the file.
lastKey() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
lastKeyBuffer - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Key previously appended.
lastKeyLength - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
 
lastKeyOffset - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
 
lastNodeId - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
lastOper - Variable in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
Deprecated.  
lastRow() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
 
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
 
LastSequenceId - Interface in org.apache.hadoop.hbase.regionserver
Last flushed sequence Ids for the regions 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
 
LATESTVERSIONONLY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.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
leafWriters - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
LEASE_SOFTLIMIT_PERIOD - Static variable in class org.apache.hadoop.hbase.util.FSHDFSUtils
Lease timeout constant, sourced from HDFS upstream.
LeaseException - Exception in org.apache.hadoop.hbase.exceptions
Reports a problem with a lease
LeaseException() - Constructor for exception org.apache.hadoop.hbase.exceptions.LeaseException
default constructor
LeaseException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.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.
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 - Variable in class org.apache.hadoop.hbase.regionserver.Leases
 
Leases.LeaseStillHeldException - Exception in org.apache.hadoop.hbase.regionserver
Thrown if we are asked create a lease but lease on passed name already exists.
Leases.LeaseStillHeldException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.Leases.LeaseStillHeldException
 
LEASTSIGBITS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
leaves - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
LENASVAL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
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(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
length
length() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
lengthOfPBMagic() - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
lengthWithMvccVersion(KeyValue, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
LESS_OR_EQUAL_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
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
 
LESS_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
limit - Variable in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
 
LIMIT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
LIMIT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
limitNumMapTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated. 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
Deprecated. 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.
LINENUMBER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
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
Create a sorted list of the KeyValue's in this result.
listAllRegions(Configuration) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Lists all of the regions currently in META.
listAllRegions(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Lists all of the regions currently in META.
listChildrenAndGetAsServerNames(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Lists the children of the specified znode, retrieving the data of each child as a server address.
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.
listeners - Variable in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
 
listPeers() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Map of this cluster's peers for display.
listPeers() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Map of this cluster's peers for display.
listPeersIdsAndWatch() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
List this cluster's peers' IDs
listSnapshots() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List completed snapshots.
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
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
listTables() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List all the userspace tables.
listTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List all the userspace tables matching the given pattern.
listTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
List all the userspace tables matching the given regular expression.
listTables() - Method in interface org.apache.hadoop.hbase.client.HConnection
List all the userspace tables.
LIVENODES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
 
LIVESERVERS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
load(Path, String, int, Configuration) - 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_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
 
LOAD_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
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
 
LoadBalancerProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
LoadBalancerProtos.LoadBalancerState - Class in org.apache.hadoop.hbase.protobuf.generated
 
LoadBalancerProtos.LoadBalancerState.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
LoadBalancerProtos.LoadBalancerStateOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
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, byte[], boolean, byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
loadBlockAndSeekToKey(HFileBlock, byte[], boolean, byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
 
loadBlockAndSeekToKey(HFileBlock, byte[], boolean, byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
 
loadBloomfilter() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
loadClass(String) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorClassLoader
 
LOADCOLUMNFAMILIESONDEMAND_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
loadDataBlockWithScanInfo(byte[], int, int, HFileBlock, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
Return the BlockWithScanInfo which contains the DataBlock with other scan info such as nextIndexedKey.
LOADED_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
LOADED_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
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.
loadHdfsRegionDirs() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Scan HDFS for all regions, recording their information into regionInfoMap
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
 
loadInstance(Class<?>, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
LOADONOPENDATAOFFSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
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.coprocessor.CoprocessorClassLoader
Determines whether we should attempt to load the given resource using the parent first before attempting to load the resource using this ClassLoader.
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 as SpanReceiver's.
loadSystemCoprocessors(Configuration, String) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Load system coprocessors.
LoadTestDataGenerator - Class in org.apache.hadoop.hbase.util.test
A generator of random data (keys/cfs/columns/values) for load testing.
LoadTestDataGenerator(int, int) - Constructor for class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
Initializes the object.
LoadTestKVGenerator - Class in org.apache.hadoop.hbase.util.test
A generator of random keys and values for load testing.
LoadTestKVGenerator(int, int) - Constructor for class org.apache.hadoop.hbase.util.test.LoadTestKVGenerator
 
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.
loadValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.KeyValue
Loads this object's value 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:'
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
 
locateRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Find the location of the region of tableName that row lives in.
locateRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Gets the location of the region of regionName.
locateRegions(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Gets the locations of all regions in the specified table, tableName.
locateRegions(byte[], boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Gets the locations of all regions in the specified table, tableName.
location - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
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.ReplicationZookeeper
Try to set a lock in another server's znode.
LOCKOWNER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
LOCKOWNER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
LockTimeoutException - Exception in org.apache.hadoop.hbase.exceptions
 
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.ScannerCallable
 
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.errorhandling.ForeignExceptionDispatcher
 
LOG - Static variable in class org.apache.hadoop.hbase.fs.HFileSystem
 
LOG - Static variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
LOG - Static variable in class org.apache.hadoop.hbase.ipc.HBaseClientRPC
 
LOG - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
LOG - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServerRPC
 
LOG - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
LOG - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSplit
 
LOG - Static variable in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
 
LOG - Static variable in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
Deprecated.  
LOG - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
 
LOG - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
LOG - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
 
LOG - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
LOG - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionThriftServer
 
LOG - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
LOG - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.HLog
 
LOG - Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
LOG - Static variable in class org.apache.hadoop.hbase.security.access.AccessController
 
LOG - Static variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
 
LOG - Static variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
 
LOG - Static variable in class org.apache.hadoop.hbase.snapshot.ReferenceRegionHFilesTask
 
LOG - Static variable in class org.apache.hadoop.hbase.snapshot.TableInfoCopyTask
 
LOG - Static variable in class org.apache.hadoop.hbase.thrift.HbaseHandlerMetricsProxy
 
LOG - Variable in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
LOG - Variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
LOG - Static variable in class org.apache.hadoop.hbase.trace.HBaseLocalFileSpanReceiver
 
LOG - Variable in enum org.apache.hadoop.hbase.util.ChecksumType
 
LOG - Static variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
 
LOG - Static variable in class org.apache.hadoop.hbase.util.HBaseFsckRepair
 
LOG - Static variable in class org.apache.hadoop.hbase.util.Threads
 
LOG - Static variable in class org.apache.hadoop.hbase.ZNodeClearer
 
LOG2_SQUARED - Static variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Used in computing the optimal Bloom filter size.
LOG_PER_ROW_COUNT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
 
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 HLogs in the old logs folder.
LogCleaner(int, Stoppable, Configuration, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.master.cleaner.LogCleaner
 
logCloseRequested() - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
The WAL is about to close.
logCloseRequested() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
logFile(String, String) - Method in interface org.apache.hadoop.hbase.util.FSVisitor.LogFileVisitor
 
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
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.
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.
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 hlog it belongs to and will log, for this region server, the current position.
logRollRequested() - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
A request was made that the WAL be rolled.
logRollRequested() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
LOGSEQUENCENUMBER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
logStatistics() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
logStats() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
logStats() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
logStats() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
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
 
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
 
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.
LONGMSG_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
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
 
lowerValueByKey(K) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
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) and LruBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, 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) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Configurable constructor.
LRUDictionary - Class in org.apache.hadoop.hbase.regionserver.wal
WALDictionary using an LRU eviction algorithm.
LRUDictionary() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.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.HBaseConfiguration
For debugging.
main(String[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
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
Deprecated.  
main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.RowCounter
Deprecated.  
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.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.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.regionserver.CompactionTool
 
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.MemStore
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.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.HLogPrettyPrinter
 
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.ExportSnapshot
 
main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
 
main(String[]) - Static method in class org.apache.hadoop.hbase.thrift.DemoClient
 
main(String[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftServer
 
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.Canary
 
main(String[]) - Static method in class org.apache.hadoop.hbase.util.Base64
Main program.
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.JenkinsHash
Compute the hash of the specified file
main(String[]) - Static method in class org.apache.hadoop.hbase.util.Merge
 
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.zookeeper.HQuorumPeer
Parse ZooKeeper configuration from HBase XML config and run a QuorumPeer.
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.ZooKeeperMainServerArg
Run the tool.
maintainStats() - Method in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
Deprecated.  
MAJOR_AND_MINOR_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
 
MAJOR_COMPACTION_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Major compaction flag in FileInfo
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
MAJOR_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
 
majorCompact(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a table or an individual region.
majorCompact(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a table or an individual region.
majorCompact(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a column family within a table or region.
majorCompact(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Major compact a column family within a table or region.
majorCompact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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.catalog.MetaEditor
Generates and returns a Delete containing the region info for the catalog table
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.BackupMasterListTmpl
 
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.RegionListTmpl
 
makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
 
makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
 
makePutFromRegionInfo(HRegionInfo) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
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.BackupMasterListTmpl
 
makeRenderer(HMaster, HBaseAdmin) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
makeRenderer(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
 
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) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
 
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
Deprecated. 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
Deprecated. 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, Result>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
Pass the key, value to reduce.
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(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_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for entry in map
MAPENTRIES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
MAPENTRY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
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
 
MapReduceProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
MapReduceProtos.ScanMetrics - Class in org.apache.hadoop.hbase.protobuf.generated
 
MapReduceProtos.ScanMetrics.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MapReduceProtos.ScanMetricsOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
markAfterLast() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
markBeforeFirst() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
markClosed(IOException) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
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) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
 
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_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
MASTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
MASTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
MASTER_HFILE_CLEANER_PLUGINS - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
 
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_jsp - Class in org.apache.hadoop.hbase.generated.master
 
master_jsp() - Constructor for class org.apache.hadoop.hbase.generated.master.master_jsp
 
MASTER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for port master listens on.
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.
MasterAdminProtocol - Interface in org.apache.hadoop.hbase
Protocol that a client uses to communicate with the Master (for admin purposes).
MasterAdminProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.AddColumnRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.AddColumnRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.AddColumnRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.AddColumnResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.AddColumnResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.AddColumnResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.AssignRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.AssignRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.AssignRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.AssignRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.AssignRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.AssignRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.BalanceRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.BalanceRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.BalanceRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.BalanceResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.BalanceResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.BalanceResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.CatalogScanRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.CatalogScanRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.CatalogScanRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.CatalogScanResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.CatalogScanResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.CatalogScanResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.CreateTableRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.CreateTableRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.CreateTableRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.CreateTableResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.CreateTableResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.CreateTableResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteColumnRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteColumnRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteColumnRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteColumnResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteColumnResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteColumnResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteSnapshotRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteSnapshotRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteSnapshotRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteSnapshotResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteSnapshotResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteSnapshotResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteTableRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteTableRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteTableRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteTableResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteTableResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DeleteTableResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DisableTableRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DisableTableRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DisableTableRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DisableTableResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DisableTableResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DisableTableResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DispatchMergingRegionsRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DispatchMergingRegionsRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DispatchMergingRegionsRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DispatchMergingRegionsResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DispatchMergingRegionsResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.DispatchMergingRegionsResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.EnableCatalogJanitorRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.EnableCatalogJanitorRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.EnableCatalogJanitorRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.EnableCatalogJanitorResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.EnableCatalogJanitorResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.EnableCatalogJanitorResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.EnableTableRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.EnableTableRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.EnableTableRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.EnableTableResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.EnableTableResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.EnableTableResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsCatalogJanitorEnabledRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsCatalogJanitorEnabledRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsCatalogJanitorEnabledRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsCatalogJanitorEnabledResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsCatalogJanitorEnabledResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsRestoreSnapshotDoneRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsRestoreSnapshotDoneRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsRestoreSnapshotDoneResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsRestoreSnapshotDoneResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsSnapshotDoneRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsSnapshotDoneRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsSnapshotDoneRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsSnapshotDoneResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsSnapshotDoneResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.IsSnapshotDoneResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ListSnapshotRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ListSnapshotRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ListSnapshotRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ListSnapshotResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ListSnapshotResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ListSnapshotResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.MasterAdminService - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.MasterAdminService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
MasterAdminProtos.MasterAdminService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.MasterAdminService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.MasterAdminService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ModifyColumnRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ModifyColumnRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ModifyColumnRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ModifyColumnResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ModifyColumnResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ModifyColumnResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ModifyTableRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ModifyTableRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ModifyTableRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ModifyTableResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ModifyTableResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ModifyTableResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.MoveRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.MoveRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.MoveRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.MoveRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.MoveRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.MoveRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.OfflineRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.OfflineRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.OfflineRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.OfflineRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.OfflineRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.OfflineRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.RestoreSnapshotRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.RestoreSnapshotRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.RestoreSnapshotRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.RestoreSnapshotResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.RestoreSnapshotResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.RestoreSnapshotResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.SetBalancerRunningRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.SetBalancerRunningRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.SetBalancerRunningRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.SetBalancerRunningResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.SetBalancerRunningResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.SetBalancerRunningResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ShutdownRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ShutdownRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ShutdownRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ShutdownResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ShutdownResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.ShutdownResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.StopMasterRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.StopMasterRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.StopMasterRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.StopMasterResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.StopMasterResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.StopMasterResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.TakeSnapshotRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.TakeSnapshotRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.TakeSnapshotRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.TakeSnapshotResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.TakeSnapshotResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.TakeSnapshotResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.UnassignRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.UnassignRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.UnassignRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.UnassignRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.UnassignRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterAdminProtos.UnassignRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
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.
MasterCoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
Provides clients with an RPC connection to call coprocessor endpoint Services against the active master.
MasterCoprocessorRpcChannel(HConnection) - Constructor for class org.apache.hadoop.hbase.ipc.MasterCoprocessorRpcChannel
 
MASTERCOPROCESSORS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
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, MetricsMaster, boolean) - Constructor for class org.apache.hadoop.hbase.master.MasterFileSystem
 
MasterMonitorProtocol - Interface in org.apache.hadoop.hbase
Protocol that a client uses to communicate with the Master (for monitoring purposes).
MasterMonitorProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetClusterStatusRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetClusterStatusRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetClusterStatusRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetClusterStatusResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetClusterStatusResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetClusterStatusResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetSchemaAlterStatusRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetSchemaAlterStatusRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetSchemaAlterStatusResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetSchemaAlterStatusResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetTableDescriptorsRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetTableDescriptorsRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetTableDescriptorsRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetTableDescriptorsResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetTableDescriptorsResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.GetTableDescriptorsResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.MasterMonitorService - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.MasterMonitorService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService
 
MasterMonitorProtos.MasterMonitorService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.MasterMonitorService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterMonitorProtos.MasterMonitorService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterNotRunningException - Exception in org.apache.hadoop.hbase.exceptions
Thrown if the master is not running
MasterNotRunningException() - Constructor for exception org.apache.hadoop.hbase.exceptions.MasterNotRunningException
default constructor
MasterNotRunningException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.MasterNotRunningException
Constructor
MasterNotRunningException(Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.MasterNotRunningException
Constructor taking another exception.
MasterNotRunningException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.MasterNotRunningException
 
MasterObserver - Interface in org.apache.hadoop.hbase.coprocessor
Defines coprocessor hooks for interacting with operations on the HMaster process.
MasterProtocol - Interface in org.apache.hadoop.hbase
Functions implemented by all the master protocols: e.g.
MasterProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterProtos.IsMasterRunningRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterProtos.IsMasterRunningRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterProtos.IsMasterRunningRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterProtos.IsMasterRunningResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterProtos.IsMasterRunningResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterProtos.IsMasterRunningResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterProtos.MasterService - Class in org.apache.hadoop.hbase.protobuf.generated
 
MasterProtos.MasterService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
 
MasterProtos.MasterService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterProtos.MasterService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MasterProtos.MasterService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
 
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, Path) - 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() - 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(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.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)
matchedColumn - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
matcher - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
matchesFamily(byte[], 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(byte[], 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(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue
Checks if column matches.
matchingColumnNoDelimiter(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingFamily(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingFamily(byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingFamily(KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingNode - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
 
matchingQualifier(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingQualifier(byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingQualifier(KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingRow(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingRow(byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingRow(KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue
 
matchingRowColumn(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Compares the row and column of two keyvalues for equality
matchingRows(KeyValue, byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
matchingRows(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Compares the row of two keyvalues for equality
matchingRows(KeyValue, short, KeyValue, short) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
matchingRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
 
matchingRowsGreaterTimestamp(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Compares the row and timestamp of two keys Was called matchesWithoutColumn in HStoreKey.
matchPermission(User, byte[], 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, byte[], byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
max(byte[], 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_BYTES - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
MAX_CACHED_HBASE_INSTANCES - Static variable in class org.apache.hadoop.hbase.client.HConnectionManager
 
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_FAMILY_LENGTH - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
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_FORMAT_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Maximum supported HFile format version
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 class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
MAX_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
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_ROW_LENGTH - Static variable in class org.apache.hadoop.hbase.HConstants
Max length a row can have because of the limitation in TFile.
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_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
 
MAXCOLUMN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
maxColumnInclusive - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
MAXCOLUMNINCLUSIVE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.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
 
MAXHEAPMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
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.HBaseClient
 
maxIdleTime - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
MAXIMUM_KEY_LENGTH - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Maximum length of key in HFile.
MAXIMUM_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
 
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
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.ScanQueryMatcher
readPoint over which the KVs are unconditionally included
MAXRESULTSIZE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
maxRetries - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
maxRowLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
maxScannerResultSize - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
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
 
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.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.protobuf.generated.ClientProtos.Get
 
MAXVERSIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
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
 
mbean - Variable in class org.apache.hadoop.hbase.metrics.HBaseInfo
Deprecated.  
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
 
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
 
md5PrefixedKey(long) - Static method in class org.apache.hadoop.hbase.util.test.LoadTestKVGenerator
Converts the given key to string, and prefixes it with the MD5 hash of the index's string representation.
MEAN_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
MEAN_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
mechanismName - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
 
median(byte[], 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 class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
MEDIAN_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
member - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
 
memberName - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
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 - Class in org.apache.hadoop.hbase.regionserver
The MemStore holds in-memory modifications to the Store.
MemStore() - Constructor for class org.apache.hadoop.hbase.regionserver.MemStore
Default constructor.
MemStore(Configuration, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStore
Constructor.
MemStore.MemStoreScanner - Class in org.apache.hadoop.hbase.regionserver
 
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_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MEMSTORE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
MemStoreChunkPool - Class in org.apache.hadoop.hbase.regionserver
A pool of MemStoreLAB.Chunk instances.
MemStoreLAB - Class in org.apache.hadoop.hbase.regionserver
A memstore-local allocation buffer.
MemStoreLAB() - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreLAB
 
MemStoreLAB(Configuration, MemStoreChunkPool) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreLAB
 
MemStoreLAB.Allocation - Class in org.apache.hadoop.hbase.regionserver
The result of a single allocation.
memstoreReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
 
memstoreSize - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
MEMSTORESIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
MEMSTORESIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
merge(Configuration, Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Merge two configurations.
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
 
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
mergeCall(ClientProtos.CoprocessorServiceCall) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
mergeCellBlockMeta(RPCProtos.CellBlockMeta) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
mergeCellBlockMeta(RPCProtos.CellBlockMeta) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
mergeClusterId(AdminProtos.UUID) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
mergeClusterId(ClusterIdProtos.ClusterId) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
mergeClusterStatus(ClusterStatusProtos.ClusterStatus) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
mergeColumnFamilies(HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
mergeColumnFamilies(HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
mergeComparable(ComparatorProtos.ByteArrayComparable) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
mergeComparable(ComparatorProtos.ByteArrayComparable) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
mergeComparable(ComparatorProtos.ByteArrayComparable) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
mergeComparator(ComparatorProtos.Comparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
mergeComparator(ComparatorProtos.Comparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
mergeComparator(ComparatorProtos.Comparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
mergeCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
mergeCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
mergeCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
mergeCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
mergeCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
mergeCondition(ClientProtos.Condition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
mergeDestinationServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
mergeDestServerName(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
MergedRegionHandler - Class in org.apache.hadoop.hbase.master.handler
Handles MERGE regions event on Master, master receive the merge report from the regionserver, then offline the merging regions and online the merged region.Here region_a sorts before region_b.
MergedRegionHandler(Server, AssignmentManager, ServerName, List<HRegionInfo>) - Constructor for class org.apache.hadoop.hbase.master.handler.MergedRegionHandler
 
mergeEdit(AdminProtos.WALEntry.WALEdit) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
mergeException(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
mergeException(RPCProtos.ExceptionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
mergeFilter(HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
mergeFilter(HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
mergeFilter(HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
mergeFilter(HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
mergeFilter(HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
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) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
mergeFrom(AccessControlProtos.CheckPermissionsRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
mergeFrom(AccessControlProtos.CheckPermissionsResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
mergeFrom(AccessControlProtos.GrantRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
mergeFrom(AccessControlProtos.GrantResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
mergeFrom(AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
mergeFrom(AccessControlProtos.RevokeRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
mergeFrom(AccessControlProtos.RevokeResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
mergeFrom(AccessControlProtos.UserPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
mergeFrom(AccessControlProtos.UserPermissionsRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
mergeFrom(AccessControlProtos.UserPermissionsResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
mergeFrom(AccessControlProtos.UserTablePermissions) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
mergeFrom(AccessControlProtos.UserTablePermissions.UserPermissions) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
mergeFrom(AdminProtos.CloseRegionRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
mergeFrom(AdminProtos.CloseRegionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
mergeFrom(AdminProtos.CompactRegionRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
mergeFrom(AdminProtos.CompactRegionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
mergeFrom(AdminProtos.FlushRegionRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
mergeFrom(AdminProtos.FlushRegionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
mergeFrom(AdminProtos.GetOnlineRegionRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
mergeFrom(AdminProtos.GetOnlineRegionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
mergeFrom(AdminProtos.GetRegionInfoRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
mergeFrom(AdminProtos.GetRegionInfoResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
mergeFrom(AdminProtos.GetServerInfoRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
mergeFrom(AdminProtos.GetServerInfoResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
mergeFrom(AdminProtos.GetStoreFileRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
mergeFrom(AdminProtos.GetStoreFileResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
mergeFrom(AdminProtos.MergeRegionsRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
mergeFrom(AdminProtos.MergeRegionsResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
mergeFrom(AdminProtos.OpenRegionRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
mergeFrom(AdminProtos.OpenRegionRequest.RegionOpenInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
mergeFrom(AdminProtos.OpenRegionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
mergeFrom(AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
mergeFrom(AdminProtos.ReplicateWALEntryResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
mergeFrom(AdminProtos.RollWALWriterRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
mergeFrom(AdminProtos.RollWALWriterResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
mergeFrom(AdminProtos.ServerInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
mergeFrom(AdminProtos.SplitRegionRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
mergeFrom(AdminProtos.SplitRegionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
mergeFrom(AdminProtos.StopServerRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
mergeFrom(AdminProtos.StopServerResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
mergeFrom(AdminProtos.UUID) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
mergeFrom(AdminProtos.WALEntry) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
mergeFrom(AdminProtos.WALEntry.WALEdit) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
mergeFrom(AdminProtos.WALEntry.WALEdit.FamilyScope) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
mergeFrom(AdminProtos.WALEntry.WALKey) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
mergeFrom(AggregateProtos.AggregateArgument) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
mergeFrom(AggregateProtos.AggregateResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
mergeFrom(AuthenticationProtos.AuthenticationKey) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
mergeFrom(AuthenticationProtos.Token) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
mergeFrom(AuthenticationProtos.TokenIdentifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest.Builder
 
mergeFrom(AuthenticationProtos.TokenRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
mergeFrom(AuthenticationProtos.TokenResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
mergeFrom(AuthenticationProtos.WhoAmIRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
mergeFrom(AuthenticationProtos.WhoAmIResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
mergeFrom(ClientProtos.ActionResult) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
mergeFrom(ClientProtos.BulkLoadHFileRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
mergeFrom(ClientProtos.BulkLoadHFileRequest.FamilyPath) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
mergeFrom(ClientProtos.BulkLoadHFileResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
mergeFrom(ClientProtos.Column) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
mergeFrom(ClientProtos.Condition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
mergeFrom(ClientProtos.CoprocessorServiceCall) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
mergeFrom(ClientProtos.CoprocessorServiceRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
mergeFrom(ClientProtos.CoprocessorServiceResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
mergeFrom(ClientProtos.Get) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
mergeFrom(ClientProtos.GetRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
mergeFrom(ClientProtos.GetResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
mergeFrom(ClientProtos.MultiAction) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
mergeFrom(ClientProtos.MultiGetRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
mergeFrom(ClientProtos.MultiGetResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
mergeFrom(ClientProtos.MultiRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
mergeFrom(ClientProtos.MultiResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
mergeFrom(ClientProtos.MutateRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
mergeFrom(ClientProtos.MutateResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
mergeFrom(ClientProtos.MutationProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
mergeFrom(ClientProtos.MutationProto.ColumnValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
mergeFrom(ClientProtos.MutationProto.ColumnValue.QualifierValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
mergeFrom(ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
mergeFrom(ClientProtos.Scan) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
mergeFrom(ClientProtos.ScanRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
mergeFrom(ClientProtos.ScanResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
mergeFrom(ClusterIdProtos.ClusterId) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
mergeFrom(ClusterStatusProtos.ClusterStatus) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
mergeFrom(ClusterStatusProtos.LiveServerInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
mergeFrom(ClusterStatusProtos.RegionInTransition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
mergeFrom(ClusterStatusProtos.RegionState) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
mergeFrom(ComparatorProtos.BinaryComparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
mergeFrom(ComparatorProtos.BinaryPrefixComparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
mergeFrom(ComparatorProtos.BitComparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
mergeFrom(ComparatorProtos.ByteArrayComparable) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
mergeFrom(ComparatorProtos.Comparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
mergeFrom(ComparatorProtos.NullComparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
mergeFrom(ComparatorProtos.RegexStringComparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
mergeFrom(ComparatorProtos.SubstringComparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
mergeFrom(ErrorHandlingProtos.ForeignExceptionMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
mergeFrom(ErrorHandlingProtos.GenericExceptionMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
mergeFrom(ErrorHandlingProtos.StackTraceElementMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
mergeFrom(FilterProtos.ColumnCountGetFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
mergeFrom(FilterProtos.ColumnPaginationFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
mergeFrom(FilterProtos.ColumnPrefixFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
mergeFrom(FilterProtos.ColumnRangeFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
mergeFrom(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
mergeFrom(FilterProtos.DependentColumnFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
mergeFrom(FilterProtos.FamilyFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
mergeFrom(FilterProtos.FilterList) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
mergeFrom(FilterProtos.FilterWrapper) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
mergeFrom(FilterProtos.FirstKeyOnlyFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
mergeFrom(FilterProtos.FirstKeyValueMatchingQualifiersFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
mergeFrom(FilterProtos.FuzzyRowFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
mergeFrom(FilterProtos.InclusiveStopFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
mergeFrom(FilterProtos.KeyOnlyFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
mergeFrom(FilterProtos.MultipleColumnPrefixFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
mergeFrom(FilterProtos.PageFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
mergeFrom(FilterProtos.PrefixFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
mergeFrom(FilterProtos.QualifierFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
mergeFrom(FilterProtos.RandomRowFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
mergeFrom(FilterProtos.RowFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
mergeFrom(FilterProtos.SingleColumnValueExcludeFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
mergeFrom(FilterProtos.SingleColumnValueFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
mergeFrom(FilterProtos.SkipFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
mergeFrom(FilterProtos.TimestampsFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
mergeFrom(FilterProtos.ValueFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
mergeFrom(FilterProtos.WhileMatchFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
mergeFrom(FSProtos.HBaseVersionFileContent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
mergeFrom(FSProtos.Reference) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
mergeFrom(HBaseProtos.BigDecimalMsg) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
mergeFrom(HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
mergeFrom(HBaseProtos.Cell) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
mergeFrom(HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
mergeFrom(HBaseProtos.Coprocessor) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
mergeFrom(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
mergeFrom(HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
mergeFrom(HBaseProtos.KeyValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
mergeFrom(HBaseProtos.LongMsg) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
mergeFrom(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
mergeFrom(HBaseProtos.NameInt64Pair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
mergeFrom(HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
mergeFrom(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
mergeFrom(HBaseProtos.RegionLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
mergeFrom(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
mergeFrom(HBaseProtos.ServerLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
mergeFrom(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
mergeFrom(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
mergeFrom(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
mergeFrom(HBaseProtos.TimeRange) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
mergeFrom(HFileProtos.FileInfoProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
mergeFrom(HFileProtos.FileTrailerProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
mergeFrom(LoadBalancerProtos.LoadBalancerState) - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
mergeFrom(MapReduceProtos.ScanMetrics) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
mergeFrom(MasterAdminProtos.AddColumnRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse.Builder
 
mergeFrom(MasterAdminProtos.AddColumnResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
mergeFrom(MasterAdminProtos.AssignRegionRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse.Builder
 
mergeFrom(MasterAdminProtos.AssignRegionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest.Builder
 
mergeFrom(MasterAdminProtos.BalanceRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
mergeFrom(MasterAdminProtos.BalanceResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest.Builder
 
mergeFrom(MasterAdminProtos.CatalogScanRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
mergeFrom(MasterAdminProtos.CatalogScanResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
mergeFrom(MasterAdminProtos.CreateTableRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse.Builder
 
mergeFrom(MasterAdminProtos.CreateTableResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
mergeFrom(MasterAdminProtos.DeleteColumnRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse.Builder
 
mergeFrom(MasterAdminProtos.DeleteColumnResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
mergeFrom(MasterAdminProtos.DeleteSnapshotRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse.Builder
 
mergeFrom(MasterAdminProtos.DeleteSnapshotResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
mergeFrom(MasterAdminProtos.DeleteTableRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse.Builder
 
mergeFrom(MasterAdminProtos.DeleteTableResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
mergeFrom(MasterAdminProtos.DisableTableRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse.Builder
 
mergeFrom(MasterAdminProtos.DisableTableResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
mergeFrom(MasterAdminProtos.DispatchMergingRegionsRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse.Builder
 
mergeFrom(MasterAdminProtos.DispatchMergingRegionsResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
mergeFrom(MasterAdminProtos.EnableCatalogJanitorRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
mergeFrom(MasterAdminProtos.EnableCatalogJanitorResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
mergeFrom(MasterAdminProtos.EnableTableRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse.Builder
 
mergeFrom(MasterAdminProtos.EnableTableResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest.Builder
 
mergeFrom(MasterAdminProtos.IsCatalogJanitorEnabledRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
mergeFrom(MasterAdminProtos.IsCatalogJanitorEnabledResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
mergeFrom(MasterAdminProtos.IsRestoreSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
mergeFrom(MasterAdminProtos.IsRestoreSnapshotDoneResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
mergeFrom(MasterAdminProtos.IsSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
mergeFrom(MasterAdminProtos.IsSnapshotDoneResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest.Builder
 
mergeFrom(MasterAdminProtos.ListSnapshotRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
mergeFrom(MasterAdminProtos.ListSnapshotResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
mergeFrom(MasterAdminProtos.ModifyColumnRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse.Builder
 
mergeFrom(MasterAdminProtos.ModifyColumnResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
mergeFrom(MasterAdminProtos.ModifyTableRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse.Builder
 
mergeFrom(MasterAdminProtos.ModifyTableResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
mergeFrom(MasterAdminProtos.MoveRegionRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse.Builder
 
mergeFrom(MasterAdminProtos.MoveRegionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
mergeFrom(MasterAdminProtos.OfflineRegionRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse.Builder
 
mergeFrom(MasterAdminProtos.OfflineRegionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
mergeFrom(MasterAdminProtos.RestoreSnapshotRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse.Builder
 
mergeFrom(MasterAdminProtos.RestoreSnapshotResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
mergeFrom(MasterAdminProtos.SetBalancerRunningRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
mergeFrom(MasterAdminProtos.SetBalancerRunningResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest.Builder
 
mergeFrom(MasterAdminProtos.ShutdownRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse.Builder
 
mergeFrom(MasterAdminProtos.ShutdownResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest.Builder
 
mergeFrom(MasterAdminProtos.StopMasterRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse.Builder
 
mergeFrom(MasterAdminProtos.StopMasterResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
mergeFrom(MasterAdminProtos.TakeSnapshotRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
mergeFrom(MasterAdminProtos.TakeSnapshotResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
mergeFrom(MasterAdminProtos.UnassignRegionRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse.Builder
 
mergeFrom(MasterAdminProtos.UnassignRegionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest.Builder
 
mergeFrom(MasterMonitorProtos.GetClusterStatusRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
mergeFrom(MasterMonitorProtos.GetClusterStatusResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
mergeFrom(MasterMonitorProtos.GetSchemaAlterStatusRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
mergeFrom(MasterMonitorProtos.GetSchemaAlterStatusResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
mergeFrom(MasterMonitorProtos.GetTableDescriptorsRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
mergeFrom(MasterMonitorProtos.GetTableDescriptorsResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
mergeFrom(MasterProtos.IsMasterRunningRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
mergeFrom(MasterProtos.IsMasterRunningResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
mergeFrom(MultiRowMutation.MultiMutateRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse.Builder
 
mergeFrom(MultiRowMutation.MultiMutateResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest.Builder
 
mergeFrom(MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse.Builder
 
mergeFrom(MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
mergeFrom(RegionServerStatusProtos.GetLastFlushedSequenceIdRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
mergeFrom(RegionServerStatusProtos.GetLastFlushedSequenceIdResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
mergeFrom(RegionServerStatusProtos.RegionServerReportRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
mergeFrom(RegionServerStatusProtos.RegionServerReportResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
mergeFrom(RegionServerStatusProtos.RegionServerStartupRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
mergeFrom(RegionServerStatusProtos.RegionServerStartupResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
mergeFrom(RegionServerStatusProtos.ReportRSFatalErrorRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
mergeFrom(RegionServerStatusProtos.ReportRSFatalErrorResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
mergeFrom(RowProcessorProtos.RowProcessorRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
mergeFrom(RowProcessorProtos.RowProcessorResult) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
mergeFrom(RPCProtos.CellBlockMeta) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
mergeFrom(RPCProtos.ConnectionHeader) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
mergeFrom(RPCProtos.ExceptionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
mergeFrom(RPCProtos.RequestHeader) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
mergeFrom(RPCProtos.ResponseHeader) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
mergeFrom(RPCProtos.UserInformation) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
mergeFrom(SecureBulkLoadProtos.CleanupBulkLoadRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
mergeFrom(SecureBulkLoadProtos.CleanupBulkLoadResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
mergeFrom(SecureBulkLoadProtos.DelegationTokenProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
mergeFrom(SecureBulkLoadProtos.PrepareBulkLoadRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
mergeFrom(SecureBulkLoadProtos.PrepareBulkLoadResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
mergeFrom(SecureBulkLoadProtos.SecureBulkLoadHFilesRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
mergeFrom(SecureBulkLoadProtos.SecureBulkLoadHFilesResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
mergeFrom(Tracing.RPCTInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
mergeFrom(ZooKeeperProtos.ClusterUp) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
mergeFrom(ZooKeeperProtos.Master) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
mergeFrom(ZooKeeperProtos.RegionTransition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
mergeFrom(ZooKeeperProtos.ReplicationHLogPosition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
mergeFrom(ZooKeeperProtos.ReplicationLock) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
mergeFrom(ZooKeeperProtos.ReplicationPeer) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
mergeFrom(ZooKeeperProtos.ReplicationState) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
mergeFrom(ZooKeeperProtos.RootRegionServer) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
mergeFrom(ZooKeeperProtos.SplitLogTask) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
mergeFrom(ZooKeeperProtos.Table) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
mergeFrom(Message) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
mergeFrom(ZooKeeperProtos.TableLock) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
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.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
 
mergeFsToken(SecureBulkLoadProtos.DelegationTokenProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
mergeGenericException(ErrorHandlingProtos.GenericExceptionMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
mergeGet(ClientProtos.Get) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
mergeGet(ClientProtos.Get) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
mergeHbaseVersion(FSProtos.HBaseVersionFileContent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
mergeKey(AdminProtos.WALEntry.WALKey) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
mergeLoad(HBaseProtos.ServerLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
mergeLockOwner(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
mergeMaster(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
mergeMaster(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
mergeMutation(ClientProtos.MutationProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
mergeMutation(ClientProtos.MutationProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
mergePermission(AccessControlProtos.UserPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
mergePermission(AccessControlProtos.UserPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
mergePermission(AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
mergeRegion(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
mergeRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
mergeRegionA(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
mergeRegionA(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
mergeRegionB(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
mergeRegionB(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
mergeRegionDirs(Path, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Merge hdfs data by moving from contained HbckInfo into targetRegionDir.
mergeRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
mergeRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
mergeRegions(CatalogTracker, HRegionInfo, HRegionInfo, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Merge the two regions into one in an atomic operation.
mergeRegions(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Merge two regions.
mergeRegions(RpcController, AdminProtos.MergeRegionsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
 
mergeRegions(RpcController, AdminProtos.MergeRegionsRequest, RpcCallback<AdminProtos.MergeRegionsResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
 
mergeRegions(RpcController, AdminProtos.MergeRegionsRequest, RpcCallback<AdminProtos.MergeRegionsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
mergeRegions(RpcController, AdminProtos.MergeRegionsRequest, RpcCallback<AdminProtos.MergeRegionsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
mergeRegions(AdminProtocol, HRegionInfo, HRegionInfo, boolean) - 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.HRegionServer
Merge regions on the region server.
mergeRegionSpecifier(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
mergeRegionState(ClusterStatusProtos.RegionState) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
mergeResult(ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
mergeResult(ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
mergeScan(ClientProtos.Scan) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
mergeScan(ClientProtos.Scan) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
mergeScan(ClientProtos.Scan) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
mergeServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
mergeServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
mergeServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
mergeServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
mergeServerInfo(AdminProtos.ServerInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
mergeServerLoad(HBaseProtos.ServerLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
mergeServerName(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
mergeServerName(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
mergeServerName(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
mergeSingleColumnValueFilter(FilterProtos.SingleColumnValueFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
mergeSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
mergeSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
mergeSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
mergeSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
mergeSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
mergeSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
mergeSpec(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
mergeTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
mergeTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
mergeTimeRange(HBaseProtos.TimeRange) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
mergeTimeRange(HBaseProtos.TimeRange) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
mergeTimeRange(HBaseProtos.TimeRange) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
mergeToken(AuthenticationProtos.Token) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
mergeTraceInfo(Tracing.RPCTInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
mergeUserInfo(RPCProtos.UserInformation) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
mergeValue(ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
mergeValue(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
message - Variable in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
message - Variable in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
 
MESSAGE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
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
 
META_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
A KeyValue.KVComparator for .META. catalog table KeyValues.
META_HLOG_FILE_EXTN - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.HLog
The META region's HLog filename extension
META_KEY_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
A KeyValue.KVComparator for .META. catalog table KeyValue keys.
META_ROW_DELIMITER - Static variable in class org.apache.hadoop.hbase.HConstants
delimiter used between portions of a region name
META_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
The META table's name.
META_TABLEDESC - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Table descriptor for .META. catalog table
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.
metaBlockIndexReader - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
Meta block index reader -- always single level
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 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.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.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.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.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.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.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 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.TPut
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
metaDataMap - Static variable in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
MetaEditor - Class in org.apache.hadoop.hbase.catalog
Writes region and assignment information to .META..
MetaEditor() - Constructor for class org.apache.hadoop.hbase.catalog.MetaEditor
 
METAFAMILY - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.HLog
 
METAINDEXCOUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
metaLocation - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
MetaMigrationConvertingToPB - Class in org.apache.hadoop.hbase.catalog
Deprecated. will be removed for the major release after 0.96.
MetaMigrationConvertingToPB() - Constructor for class org.apache.hadoop.hbase.catalog.MetaMigrationConvertingToPB
Deprecated.  
metaNames - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Meta block names.
MetaNodeTracker - Class in org.apache.hadoop.hbase.zookeeper
Tracks the unassigned zookeeper node used by the META table.
MetaNodeTracker(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.MetaNodeTracker
Creates a meta node tracker.
MetaReader - Class in org.apache.hadoop.hbase.catalog
Reads region and assignment information from .META..
MetaReader() - Constructor for class org.apache.hadoop.hbase.catalog.MetaReader
 
MetaReader.Visitor - Interface in org.apache.hadoop.hbase.catalog
Implementations 'visit' a catalog table row.
metaRegionExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Checks if root region exists
MetaRegionTracker - Class in org.apache.hadoop.hbase.zookeeper
Tracks the meta region server location node in zookeeper.
MetaRegionTracker(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
Creates a meta region location tracker.
METAROW - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.HLog
 
metaScan(Configuration, 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(Configuration, MetaScanner.MetaScannerVisitor, byte[]) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Scans the meta table and calls a visitor on each RowResult.
metaScan(Configuration, MetaScanner.MetaScannerVisitor, byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
Scans the meta table and calls a visitor on each RowResult.
metaScan(Configuration, MetaScanner.MetaScannerVisitor, byte[], byte[], int, byte[]) - 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 .META. table scanning logic and uses a Retryable scanner.
MetaScanner() - Constructor for class org.apache.hadoop.hbase.client.MetaScanner
 
MetaScanner.DefaultMetaScannerVisitor - Class in org.apache.hadoop.hbase.client
A MetaScannerVisitor that provides a consistent view of the table's META entries during concurrent splits (see HBASE-5986 for details).
MetaScanner.DefaultMetaScannerVisitor(Configuration) - 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 .META.
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(Configuration, byte[]) - Constructor for class org.apache.hadoop.hbase.client.MetaScanner.TableMetaScannerVisitor
 
MetaServerShutdownHandler - Class in org.apache.hadoop.hbase.master.handler
Shutdown handler for the server hosting .META.
MetaServerShutdownHandler(Server, MasterServices, DeadServer, ServerName) - Constructor for class org.apache.hadoop.hbase.master.handler.MetaServerShutdownHandler
 
metaServerZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
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
 
method - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
METHODNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
METHODNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
METHODNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
Methods - Class in org.apache.hadoop.hbase.util
 
Methods() - Constructor for class org.apache.hadoop.hbase.util.Methods
 
MetricHistogram - Interface in org.apache.hadoop.metrics2
Metrics Histogram interface.
metrics - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
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.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.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.master.MetricsMasterSource
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.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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
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.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.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.master.MetricsMasterSource
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.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
metricsContext - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
metricsDescription - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
MetricsExecutor - Interface in org.apache.hadoop.metrics2
ScheduledExecutorService for metrics.
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
 
MetricsHistogram - Class in org.apache.hadoop.hbase.metrics.histogram
Deprecated. 
MetricsHistogram(String, MetricsRegistry, String, boolean) - Constructor for class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated. Constructor to create a new histogram metric
MetricsHistogram(String, MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated. Constructor create a new (forward biased) histogram metric
MetricsHistogram(String, MetricsRegistry) - Constructor for class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated. Constructor - create a new (forward biased) histogram metric
metricsJmxContext - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
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
 
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
 
MetricsMBeanBase - Class in org.apache.hadoop.hbase.metrics
Deprecated. 
MetricsMBeanBase(MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
Deprecated.  
metricsName - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
MetricsRate - Class in org.apache.hadoop.hbase.metrics
Deprecated. 
MetricsRate(String, MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.metrics.MetricsRate
Deprecated.  
MetricsRate(String, MetricsRegistry) - Constructor for class org.apache.hadoop.hbase.metrics.MetricsRate
Deprecated.  
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) - 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
 
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
 
MetricsReplicationSource - Interface in org.apache.hadoop.hbase.replication.regionserver
Provides access to gauges and counters.
MetricsReplicationSourceImpl - Class in org.apache.hadoop.hbase.replication.regionserver
Hadoop2 implementation of MetricsReplicationSource.
MetricsReplicationSourceImpl() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceImpl
 
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
 
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
MetricsString - Class in org.apache.hadoop.hbase.metrics
Deprecated. 
MetricsString(String, MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.metrics.MetricsString
Deprecated.  
MetricsString(String, String, MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.metrics.MetricsString
Deprecated.  
MetricsThriftServerSource - Interface in org.apache.hadoop.hbase.thrift
Inteface 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
 
MetricsWALSource - Interface in org.apache.hadoop.hbase.regionserver.wal
Interface of the source that will export metrics about the region server's HLog.
MetricsWALSourceImpl - Class in org.apache.hadoop.hbase.regionserver.wal
Class that transitions metrics from HLog's 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
 
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(byte[], 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_FORMAT_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Minimum supported HFile format version
MIN_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
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_RPC_TIMEOUT - Static variable in class org.apache.hadoop.hbase.client.ServerCallable
 
MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
MIN_WAIT_DEAD_SERVER - Static variable in class org.apache.hadoop.hbase.client.ServerCallable
 
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
 
MINCOLUMN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
minColumnInclusive - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
MINCOLUMNINCLUSIVE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.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
 
MINIMUM_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
 
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_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
 
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
minVersions - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
miss(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
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(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
 
modifyColumn(RpcController, MasterAdminProtos.ModifyColumnRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
modifyColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
Modify Column of a table
modifyColumn(byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Modify the column descriptor of an existing column in an existing table
modifyColumn(RpcController, MasterAdminProtos.ModifyColumnRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
modifyColumn(RpcController, MasterAdminProtos.ModifyColumnRequest, RpcCallback<MasterAdminProtos.ModifyColumnResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
modifyColumn(RpcController, MasterAdminProtos.ModifyColumnRequest, RpcCallback<MasterAdminProtos.ModifyColumnResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
modifyColumn(RpcController, MasterAdminProtos.ModifyColumnRequest, RpcCallback<MasterAdminProtos.ModifyColumnResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
ModifyRegionUtils - Class in org.apache.hadoop.hbase.util
Utility methods for interacting with the regions.
ModifyRegionUtils.RegionFillTask - Interface in org.apache.hadoop.hbase.util
 
modifyTable(byte[], 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.master.HMaster
 
modifyTable(RpcController, MasterAdminProtos.ModifyTableRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
modifyTable(byte[], HTableDescriptor) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Modify the descriptor of an existing table
modifyTable(RpcController, MasterAdminProtos.ModifyTableRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
modifyTable(RpcController, MasterAdminProtos.ModifyTableRequest, RpcCallback<MasterAdminProtos.ModifyTableResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
modifyTable(RpcController, MasterAdminProtos.ModifyTableRequest, RpcCallback<MasterAdminProtos.ModifyTableResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
modifyTable(RpcController, MasterAdminProtos.ModifyTableRequest, RpcCallback<MasterAdminProtos.ModifyTableResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
ModifyTableHandler - Class in org.apache.hadoop.hbase.master.handler
 
ModifyTableHandler(byte[], HTableDescriptor, Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.ModifyTableHandler
 
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
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
 
MORERESULTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
moreRowsMayExistAfter(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
 
MOSTSIGBITS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
move(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Move the region r to dest.
moveAsideBadEditsFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogUtil
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
 
movedRegions - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
moveRegion(RpcController, MasterAdminProtos.MoveRegionRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
moveRegion(RpcController, MasterAdminProtos.MoveRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
moveRegion(RpcController, MasterAdminProtos.MoveRegionRequest, RpcCallback<MasterAdminProtos.MoveRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
moveRegion(RpcController, MasterAdminProtos.MoveRegionRequest, RpcCallback<MasterAdminProtos.MoveRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
moveRegion(RpcController, MasterAdminProtos.MoveRegionRequest, RpcCallback<MasterAdminProtos.MoveRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
moveTableToTemp(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
Move the specified table to the hbase temp directory
moveToTemp(Path) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
Move the specified file/directory to the hbase temp directory.
mr - Variable in class org.apache.hadoop.hbase.metrics.HBaseInfo
Deprecated.  
MULITPLE_FAMILIES_POSSIBLE - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
multi(RpcController, ClientProtos.MultiRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface
 
multi(RpcController, ClientProtos.MultiRequest, RpcCallback<ClientProtos.MultiResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Interface
 
multi(RpcController, ClientProtos.MultiRequest, RpcCallback<ClientProtos.MultiResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
multi(RpcController, ClientProtos.MultiRequest, RpcCallback<ClientProtos.MultiResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Stub
 
multi(RpcController, ClientProtos.MultiRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
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
 
multiGet(RpcController, ClientProtos.MultiGetRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface
 
multiGet(RpcController, ClientProtos.MultiGetRequest, RpcCallback<ClientProtos.MultiGetResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Interface
 
multiGet(RpcController, ClientProtos.MultiGetRequest, RpcCallback<ClientProtos.MultiGetResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
multiGet(RpcController, ClientProtos.MultiGetRequest, RpcCallback<ClientProtos.MultiGetResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Stub
 
multiGet(RpcController, ClientProtos.MultiGetRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Get multi data from a table.
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.
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(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
 
MultiRowMutation - Class in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutation.MultiMutateRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutation.MultiMutateRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutation.MultiMutateRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutation.MultiMutateResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutation.MultiMutateResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutation.MultiMutateResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutation.MultiRowMutationService - Class in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutation.MultiRowMutationService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService
 
MultiRowMutation.MultiRowMutationService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutation.MultiRowMutationService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutation.MultiRowMutationService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
 
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
 
MultiRowMutationProcessorProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
MultiRowResource - Class in org.apache.hadoop.hbase.rest
 
MultiRowResource(TableResource, 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
A base for MultiTableInputFormats.
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
 
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
 
MultiVersionConsistencyControl - Class in org.apache.hadoop.hbase.regionserver
Manages the read/write consistency within memstore.
MultiVersionConsistencyControl() - Constructor for class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
Default constructor.
MultiVersionConsistencyControl.WriteEntry - Class in org.apache.hadoop.hbase.regionserver
 
MURMUR_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
Constant to denote MurmurHash.
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
 
MUST_PASS_ALL_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
 
MUST_PASS_ONE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
 
mutate(RpcController, ClientProtos.MutateRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface
 
mutate(RpcController, ClientProtos.MutateRequest, RpcCallback<ClientProtos.MutateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Interface
 
mutate(RpcController, ClientProtos.MutateRequest, RpcCallback<ClientProtos.MutateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
mutate(RpcController, ClientProtos.MutateRequest, RpcCallback<ClientProtos.MutateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Stub
 
mutate(RpcController, ClientProtos.MutateRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Mutate data in a table.
MUTATE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
mutateRegions(CatalogTracker, List<HRegionInfo>, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Adds and Removes the specified regions from .META.
mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
Performs multiple mutations atomically on a single row.
mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Performs multiple mutations atomically on a single row.
mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
mutateRow(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
mutateRows(RpcController, MultiRowMutation.MultiMutateRequest, RpcCallback<MultiRowMutation.MultiMutateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
 
mutateRows(RpcController, MultiRowMutation.MultiMutateRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService.BlockingInterface
 
mutateRows(RpcController, MultiRowMutation.MultiMutateRequest, RpcCallback<MultiRowMutation.MultiMutateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService.Interface
 
mutateRows(RpcController, MultiRowMutation.MultiMutateRequest, RpcCallback<MultiRowMutation.MultiMutateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService
 
mutateRows(RpcController, MultiRowMutation.MultiMutateRequest, RpcCallback<MultiRowMutation.MultiMutateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService.Stub
 
mutateRows(HRegion, List<ClientProtos.MutationProto>, CellScanner) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Mutate a list of rows atomically.
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>) - 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.
mutateRowTs(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
MUTATETYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
Mutation - Class in org.apache.hadoop.hbase.client
 
Mutation() - Constructor for class org.apache.hadoop.hbase.client.Mutation
 
MUTATION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
MUTATION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
MUTATIONREQUEST_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
MutationSerialization - Class in org.apache.hadoop.hbase.mapreduce
 
MutationSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.MutationSerialization
 
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
 

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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
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
 
nameToType(String) - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
Map a checksum name to a specific type.
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.
needsBalance(ClusterLoadState) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
needsCompaction(Collection<StoreFile>, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
 
needsCompaction(Collection<StoreFile>, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactionPolicy
 
needsCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Checks every store to see if one has too many store files
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
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
negativeIndex - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
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
 
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
 
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
 
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService
 
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
 
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService
 
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
 
newBlockingStub(BlockingRpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
 
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() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
newBuilder(AccessControlProtos.CheckPermissionsRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
newBuilder(AccessControlProtos.CheckPermissionsResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
newBuilder(AccessControlProtos.GrantRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
newBuilder(AccessControlProtos.GrantResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
newBuilder(AccessControlProtos.Permission) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
newBuilder(AccessControlProtos.RevokeRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
newBuilder(AccessControlProtos.RevokeResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
newBuilder(AccessControlProtos.UserPermission) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
newBuilder(AccessControlProtos.UserPermissionsRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
newBuilder(AccessControlProtos.UserPermissionsResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
newBuilder(AccessControlProtos.UserTablePermissions) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
newBuilder(AccessControlProtos.UserTablePermissions.UserPermissions) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
newBuilder(AdminProtos.CloseRegionRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
newBuilder(AdminProtos.CloseRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
newBuilder(AdminProtos.CompactRegionRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
newBuilder(AdminProtos.CompactRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
newBuilder(AdminProtos.FlushRegionRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
newBuilder(AdminProtos.FlushRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
newBuilder(AdminProtos.GetOnlineRegionRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
newBuilder(AdminProtos.GetOnlineRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
newBuilder(AdminProtos.GetRegionInfoRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
newBuilder(AdminProtos.GetRegionInfoResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
newBuilder(AdminProtos.GetServerInfoRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
newBuilder(AdminProtos.GetServerInfoResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
newBuilder(AdminProtos.GetStoreFileRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
newBuilder(AdminProtos.GetStoreFileResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
newBuilder(AdminProtos.MergeRegionsRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
newBuilder(AdminProtos.MergeRegionsResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
newBuilder(AdminProtos.OpenRegionRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
newBuilder(AdminProtos.OpenRegionRequest.RegionOpenInfo) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
newBuilder(AdminProtos.OpenRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
newBuilder(AdminProtos.ReplicateWALEntryRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
newBuilder(AdminProtos.ReplicateWALEntryResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
newBuilder(AdminProtos.RollWALWriterRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
newBuilder(AdminProtos.RollWALWriterResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
newBuilder(AdminProtos.ServerInfo) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
newBuilder(AdminProtos.SplitRegionRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
newBuilder(AdminProtos.SplitRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
newBuilder(AdminProtos.StopServerRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
newBuilder(AdminProtos.StopServerResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
newBuilder(AdminProtos.UUID) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
newBuilder(AdminProtos.WALEntry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
newBuilder(AdminProtos.WALEntry.WALEdit.FamilyScope) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
newBuilder(AdminProtos.WALEntry.WALEdit) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
newBuilder(AdminProtos.WALEntry.WALKey) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
newBuilder(AggregateProtos.AggregateArgument) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
newBuilder(AggregateProtos.AggregateResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
newBuilder(AuthenticationProtos.AuthenticationKey) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
newBuilder(AuthenticationProtos.Token) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
newBuilder(AuthenticationProtos.TokenIdentifier) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
newBuilder(AuthenticationProtos.TokenRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
newBuilder(AuthenticationProtos.TokenResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
newBuilder(AuthenticationProtos.WhoAmIRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
newBuilder(AuthenticationProtos.WhoAmIResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
newBuilder(ClientProtos.ActionResult) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
newBuilder(ClientProtos.BulkLoadHFileRequest.FamilyPath) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
newBuilder(ClientProtos.BulkLoadHFileRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
newBuilder(ClientProtos.BulkLoadHFileResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
newBuilder(ClientProtos.Column) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
newBuilder(ClientProtos.Condition) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
newBuilder(ClientProtos.CoprocessorServiceCall) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
newBuilder(ClientProtos.CoprocessorServiceRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
newBuilder(ClientProtos.CoprocessorServiceResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
newBuilder(ClientProtos.Get) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
newBuilder(ClientProtos.GetRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
newBuilder(ClientProtos.GetResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
newBuilder(ClientProtos.MultiAction) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
newBuilder(ClientProtos.MultiGetRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
newBuilder(ClientProtos.MultiGetResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
newBuilder(ClientProtos.MultiRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
newBuilder(ClientProtos.MultiResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
newBuilder(ClientProtos.MutateRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
newBuilder(ClientProtos.MutateResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
newBuilder(ClientProtos.MutationProto.ColumnValue) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
newBuilder(ClientProtos.MutationProto.ColumnValue.QualifierValue) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
newBuilder(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
newBuilder(ClientProtos.Result) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
newBuilder(ClientProtos.Scan) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
newBuilder(ClientProtos.ScanRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
newBuilder(ClientProtos.ScanResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
newBuilder(ClusterIdProtos.ClusterId) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
newBuilder(ClusterStatusProtos.ClusterStatus) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
newBuilder(ClusterStatusProtos.LiveServerInfo) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
newBuilder(ClusterStatusProtos.RegionInTransition) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
newBuilder(ClusterStatusProtos.RegionState) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
newBuilder(ComparatorProtos.BinaryComparator) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
newBuilder(ComparatorProtos.BinaryPrefixComparator) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
newBuilder(ComparatorProtos.BitComparator) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
newBuilder(ComparatorProtos.ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
newBuilder(ComparatorProtos.Comparator) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
newBuilder(ComparatorProtos.NullComparator) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
newBuilder(ComparatorProtos.RegexStringComparator) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
newBuilder(ComparatorProtos.SubstringComparator) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
newBuilder(ErrorHandlingProtos.ForeignExceptionMessage) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
newBuilder(ErrorHandlingProtos.GenericExceptionMessage) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
newBuilder(ErrorHandlingProtos.StackTraceElementMessage) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
newBuilder(FilterProtos.ColumnCountGetFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
newBuilder(FilterProtos.ColumnPaginationFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
newBuilder(FilterProtos.ColumnPrefixFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
newBuilder(FilterProtos.ColumnRangeFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
newBuilder(FilterProtos.CompareFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
newBuilder(FilterProtos.DependentColumnFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
newBuilder(FilterProtos.FamilyFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
newBuilder(FilterProtos.FilterList) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
newBuilder(FilterProtos.FilterWrapper) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
newBuilder(FilterProtos.FirstKeyOnlyFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
newBuilder(FilterProtos.FirstKeyValueMatchingQualifiersFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
newBuilder(FilterProtos.FuzzyRowFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
newBuilder(FilterProtos.InclusiveStopFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
newBuilder(FilterProtos.KeyOnlyFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
newBuilder(FilterProtos.MultipleColumnPrefixFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
newBuilder(FilterProtos.PageFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
newBuilder(FilterProtos.PrefixFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
newBuilder(FilterProtos.QualifierFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
newBuilder(FilterProtos.RandomRowFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
newBuilder(FilterProtos.RowFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
newBuilder(FilterProtos.SingleColumnValueExcludeFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
newBuilder(FilterProtos.SingleColumnValueFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
newBuilder(FilterProtos.SkipFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
newBuilder(FilterProtos.TimestampsFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
newBuilder(FilterProtos.ValueFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
newBuilder(FilterProtos.WhileMatchFilter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
newBuilder(FSProtos.HBaseVersionFileContent) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
newBuilder(FSProtos.Reference) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
newBuilder(HBaseProtos.BigDecimalMsg) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
newBuilder(HBaseProtos.BytesBytesPair) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
newBuilder(HBaseProtos.Cell) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
newBuilder(HBaseProtos.ColumnFamilySchema) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
newBuilder(HBaseProtos.Coprocessor) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
newBuilder(HBaseProtos.EmptyMsg) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
newBuilder(HBaseProtos.Filter) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
newBuilder(HBaseProtos.KeyValue) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
newBuilder(HBaseProtos.LongMsg) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
newBuilder(HBaseProtos.NameBytesPair) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
newBuilder(HBaseProtos.NameInt64Pair) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
newBuilder(HBaseProtos.NameStringPair) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
newBuilder(HBaseProtos.RegionInfo) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
newBuilder(HBaseProtos.RegionLoad) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
newBuilder(HBaseProtos.RegionSpecifier) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
newBuilder(HBaseProtos.ServerLoad) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
newBuilder(HBaseProtos.ServerName) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
newBuilder(HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
newBuilder(HBaseProtos.TableSchema) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
newBuilder(HBaseProtos.TimeRange) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
newBuilder(HFileProtos.FileInfoProto) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
newBuilder(HFileProtos.FileTrailerProto) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
newBuilder(LoadBalancerProtos.LoadBalancerState) - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
newBuilder(MapReduceProtos.ScanMetrics) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
newBuilder(MasterAdminProtos.AddColumnRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
newBuilder(MasterAdminProtos.AddColumnResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
newBuilder(MasterAdminProtos.AssignRegionRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
newBuilder(MasterAdminProtos.AssignRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
newBuilder(MasterAdminProtos.BalanceRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
newBuilder(MasterAdminProtos.BalanceResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
newBuilder(MasterAdminProtos.CatalogScanRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
newBuilder(MasterAdminProtos.CatalogScanResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
newBuilder(MasterAdminProtos.CreateTableRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
newBuilder(MasterAdminProtos.CreateTableResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
newBuilder(MasterAdminProtos.DeleteColumnRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
newBuilder(MasterAdminProtos.DeleteColumnResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
newBuilder(MasterAdminProtos.DeleteSnapshotRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
newBuilder(MasterAdminProtos.DeleteSnapshotResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
newBuilder(MasterAdminProtos.DeleteTableRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
newBuilder(MasterAdminProtos.DeleteTableResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
newBuilder(MasterAdminProtos.DisableTableRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
newBuilder(MasterAdminProtos.DisableTableResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
newBuilder(MasterAdminProtos.DispatchMergingRegionsRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
newBuilder(MasterAdminProtos.DispatchMergingRegionsResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
newBuilder(MasterAdminProtos.EnableCatalogJanitorRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
newBuilder(MasterAdminProtos.EnableCatalogJanitorResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
newBuilder(MasterAdminProtos.EnableTableRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
newBuilder(MasterAdminProtos.EnableTableResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
newBuilder(MasterAdminProtos.IsCatalogJanitorEnabledRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
newBuilder(MasterAdminProtos.IsCatalogJanitorEnabledResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
newBuilder(MasterAdminProtos.IsRestoreSnapshotDoneRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
newBuilder(MasterAdminProtos.IsRestoreSnapshotDoneResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
newBuilder(MasterAdminProtos.IsSnapshotDoneRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
newBuilder(MasterAdminProtos.IsSnapshotDoneResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
newBuilder(MasterAdminProtos.ListSnapshotRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
newBuilder(MasterAdminProtos.ListSnapshotResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
newBuilder(MasterAdminProtos.ModifyColumnRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
newBuilder(MasterAdminProtos.ModifyColumnResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
newBuilder(MasterAdminProtos.ModifyTableRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
newBuilder(MasterAdminProtos.ModifyTableResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
newBuilder(MasterAdminProtos.MoveRegionRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
newBuilder(MasterAdminProtos.MoveRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
newBuilder(MasterAdminProtos.OfflineRegionRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
newBuilder(MasterAdminProtos.OfflineRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
newBuilder(MasterAdminProtos.RestoreSnapshotRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
newBuilder(MasterAdminProtos.RestoreSnapshotResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
newBuilder(MasterAdminProtos.SetBalancerRunningRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
newBuilder(MasterAdminProtos.SetBalancerRunningResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
newBuilder(MasterAdminProtos.ShutdownRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
newBuilder(MasterAdminProtos.ShutdownResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
newBuilder(MasterAdminProtos.StopMasterRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
newBuilder(MasterAdminProtos.StopMasterResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
newBuilder(MasterAdminProtos.TakeSnapshotRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
newBuilder(MasterAdminProtos.TakeSnapshotResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
newBuilder(MasterAdminProtos.UnassignRegionRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
newBuilder(MasterAdminProtos.UnassignRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
newBuilder(MasterMonitorProtos.GetClusterStatusRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
newBuilder(MasterMonitorProtos.GetClusterStatusResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
newBuilder(MasterMonitorProtos.GetSchemaAlterStatusRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
newBuilder(MasterMonitorProtos.GetSchemaAlterStatusResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
newBuilder(MasterMonitorProtos.GetTableDescriptorsRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
newBuilder(MasterMonitorProtos.GetTableDescriptorsResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
newBuilder(MasterProtos.IsMasterRunningRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
newBuilder(MasterProtos.IsMasterRunningResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
newBuilder(MultiRowMutation.MultiMutateRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
newBuilder(MultiRowMutation.MultiMutateResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
newBuilder(MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
newBuilder(MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
newBuilder(RegionServerStatusProtos.GetLastFlushedSequenceIdRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
newBuilder(RegionServerStatusProtos.GetLastFlushedSequenceIdResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
newBuilder(RegionServerStatusProtos.RegionServerReportRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
newBuilder(RegionServerStatusProtos.RegionServerReportResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
newBuilder(RegionServerStatusProtos.RegionServerStartupRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
newBuilder(RegionServerStatusProtos.RegionServerStartupResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
newBuilder(RegionServerStatusProtos.ReportRSFatalErrorRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
newBuilder(RegionServerStatusProtos.ReportRSFatalErrorResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
newBuilder(RowProcessorProtos.RowProcessorRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
newBuilder(RowProcessorProtos.RowProcessorResult) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
newBuilder(RPCProtos.CellBlockMeta) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
newBuilder(RPCProtos.ConnectionHeader) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
newBuilder(RPCProtos.ExceptionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
newBuilder(RPCProtos.RequestHeader) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
newBuilder(RPCProtos.ResponseHeader) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
newBuilder(RPCProtos.UserInformation) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
newBuilder(SecureBulkLoadProtos.CleanupBulkLoadRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
newBuilder(SecureBulkLoadProtos.CleanupBulkLoadResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
newBuilder(SecureBulkLoadProtos.DelegationTokenProto) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
newBuilder(SecureBulkLoadProtos.PrepareBulkLoadRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
newBuilder(SecureBulkLoadProtos.PrepareBulkLoadResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
newBuilder(SecureBulkLoadProtos.SecureBulkLoadHFilesRequest) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
newBuilder(SecureBulkLoadProtos.SecureBulkLoadHFilesResponse) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
newBuilder(Tracing.RPCTInfo) - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
newBuilder(ZooKeeperProtos.ClusterUp) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
newBuilder(ZooKeeperProtos.Master) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
newBuilder(ZooKeeperProtos.RegionTransition) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
newBuilder(ZooKeeperProtos.ReplicationHLogPosition) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
newBuilder(ZooKeeperProtos.ReplicationLock) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
newBuilder(ZooKeeperProtos.ReplicationPeer) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
newBuilder(ZooKeeperProtos.ReplicationState) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
newBuilder(ZooKeeperProtos.RootRegionServer) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
newBuilder(ZooKeeperProtos.SplitLogTask) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
newBuilder(ZooKeeperProtos.Table) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
newBuilder() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
newBuilder(ZooKeeperProtos.TableLock) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.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.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
newBuilderForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.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
 
newConstructor(String) - Static method in class org.apache.hadoop.hbase.util.ChecksumFactory
Returns a Constructor that can be used to create a Checksum object.
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(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
 
newDataBlockDecodingContext(Compression.Algorithm) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Creates an encoder specific decoding context, which will prepare the data before actual decoding
newDataBlockEncodingContext(Compression.Algorithm, DataBlockEncoding, byte[]) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
 
newDataBlockEncodingContext(Compression.Algorithm, DataBlockEncoding, byte[]) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Creates a encoder specific encoding context
newFileCleaner(String, Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
A utility method to create new instances of LogCleanerDelegate based on the class name of the LogCleanerDelegate.
newInstance(Hbase.Iface, ThriftMetrics, Configuration) - Static method in class org.apache.hadoop.hbase.thrift.HbaseHandlerMetricsProxy
 
newInstance(Configuration, 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.
newKey(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogUtil
 
newOnDiskDataBlockDecodingContext(Compression.Algorithm) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
create a encoder specific decoding context for reading.
newOnDiskDataBlockDecodingContext(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
newOnDiskDataBlockDecodingContext(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
newOnDiskDataBlockEncodingContext(Compression.Algorithm, byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Create an encoder specific encoding context object for writing.
newOnDiskDataBlockEncodingContext(Compression.Algorithm, byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
newOnDiskDataBlockEncodingContext(Compression.Algorithm, byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
newPair(T1, T2) - Static method in class org.apache.hadoop.hbase.util.Pair
Constructs a new pair, inferring the type via the passed arguments
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
 
newReflectiveBlockingService(AccessControlProtos.AccessControlService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
 
newReflectiveBlockingService(AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
newReflectiveBlockingService(AggregateProtos.AggregateService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
newReflectiveBlockingService(AuthenticationProtos.AuthenticationService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
 
newReflectiveBlockingService(ClientProtos.ClientService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
newReflectiveBlockingService(MasterAdminProtos.MasterAdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
newReflectiveBlockingService(MasterMonitorProtos.MasterMonitorService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService
 
newReflectiveBlockingService(MasterProtos.MasterService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
 
newReflectiveBlockingService(MultiRowMutation.MultiRowMutationService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService
 
newReflectiveBlockingService(RegionServerStatusProtos.RegionServerStatusService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
newReflectiveBlockingService(RowProcessorProtos.RowProcessorService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
 
newReflectiveBlockingService(SecureBulkLoadProtos.SecureBulkLoadService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
 
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
 
newReflectiveService(AccessControlProtos.AccessControlService.Interface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
 
newReflectiveService(AdminProtos.AdminService.Interface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
newReflectiveService(AggregateProtos.AggregateService.Interface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
newReflectiveService(AuthenticationProtos.AuthenticationService.Interface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
 
newReflectiveService(ClientProtos.ClientService.Interface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
newReflectiveService(MasterAdminProtos.MasterAdminService.Interface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
newReflectiveService(MasterMonitorProtos.MasterMonitorService.Interface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService
 
newReflectiveService(MasterProtos.MasterService.Interface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
 
newReflectiveService(MultiRowMutation.MultiRowMutationService.Interface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService
 
newReflectiveService(RegionServerStatusProtos.RegionServerStatusService.Interface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
newReflectiveService(RowProcessorProtos.RowProcessorService.Interface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
 
newReflectiveService(SecureBulkLoadProtos.SecureBulkLoadService.Interface) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
 
newServiceStub(Class<T>, RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
newSplitAlgoInstance(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter
 
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
 
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
 
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
 
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
 
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.MasterMonitorService
 
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
 
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiRowMutationService
 
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
 
newStub(RpcChannel) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
 
newThread(Runnable) - Method in class org.apache.hadoop.hbase.DaemonThreadFactory
 
next() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
next(int) - Method in class org.apache.hadoop.hbase.client.ClientScanner
Get nbRows rows.
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.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.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(List<KeyValue>) - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
Grab the next row's worth of values.
next(List<KeyValue>, String) - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
Grab the next row's worth of values.
next(List<KeyValue>, int) - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
Grab the next row's worth of values with a limit on the number of values to return.
next(List<KeyValue>, int, String) - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
Grab the next row's worth of values with a limit on the number of values to return.
next() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
next(List<KeyValue>, int) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Gets the next row of keys from the top-most scanner.
next(List<KeyValue>, int, String) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Gets the next row of keys from the top-most scanner.
next(List<KeyValue>) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Gets the next row of keys from the top-most scanner.
next(List<KeyValue>, String) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
next() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Return the next KeyValue 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.MemStore.MemStoreScanner
 
next() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
next() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
next(List<KeyValue>, int) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
Get the next row of values from this Store.
next(List<KeyValue>, int, String) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
Get the next row of values from this Store.
next(List<KeyValue>) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
next(List<KeyValue>, String) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
next() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Reader
 
next(HLog.Entry) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Reader
 
next() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
next(HLog.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
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.util.CollectionBackedScanner
 
nextBlock() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockIterator
Get the next block, or null if there are no more blocks to iterate.
nextBlockWithBlockType(BlockType) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockIterator
Similar to HFileBlock.BlockIterator.nextBlock() but checks block type, throws an exception if incorrect, and returns the HFile block
NEXTCALLSEQ_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
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.
nextLong() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Generate a random positive long number
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<KeyValue>) - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
Grab the next row's worth of values with the default limit on the number of values to return.
nextRaw(List<KeyValue>, int, String) - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
Grab the next row's worth of values with a limit on the number of values to return.
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) - 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.
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
 
NINETY_FIFTH_PERCENTILE_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
NINETY_FIFTH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
NINETY_NINETH_PERCENTILE_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
NINETY_NINETH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
NO_HASH - Static variable in class org.apache.hadoop.hbase.HRegionInfo
 
NO_NEXT_INDEXED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
The byte array represents for NO_NEXT_INDEXED_KEY; The actual value is irrelevant because this is always compared by reference.
NO_OP_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
NO_OPTIONS - Static variable in class org.apache.hadoop.hbase.util.Base64
No options specified.
NO_PERSISTENT_TS - Static variable in class org.apache.hadoop.hbase.regionserver.MemStore
Used for readability when we don't store memstore timestamp in HFile
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_SNAPSHOT_START_TIME_SPECIFIED - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Default value if no start time is specified
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.master.AssignmentManager
New unassigned node has been created.
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
 
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager.OtherRegionServerWatcher
Called when an existing node has a child node added or removed.
nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager.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.zookeeper.DrainingServerTracker
 
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.AssignmentManager
New unassigned node has been created.
nodeCreated(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager.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.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.master.AssignmentManager
Existing unassigned node has had data changed.
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
 
nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer.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.zookeeper.DeletionListener
 
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.AssignmentManager
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager.OtherRegionServerWatcher
Called when a node has been deleted
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager.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.zookeeper.DeletionListener
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.DrainingServerTracker
 
nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.MetaNodeTracker
 
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
 
NON_STARTCODE - Static variable in class org.apache.hadoop.hbase.ServerName
What to use if no startcode supplied.
NONE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
 
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
 
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
 
nonNullRowAndColumn() - Method in class org.apache.hadoop.hbase.KeyValue
 
NoOpDataBlockEncoder - Class in org.apache.hadoop.hbase.io.hfile
Does not perform any kind of encoding/decoding.
NORMAL_QOS - 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.
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.exceptions
Thrown if request for nonexistent column family.
NoSuchColumnFamilyException() - Constructor for exception org.apache.hadoop.hbase.exceptions.NoSuchColumnFamilyException
default constructor
NoSuchColumnFamilyException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.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_EQUAL_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
NotAllMetaRegionsOnlineException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when an operation requires the root and all meta regions to be online
NotAllMetaRegionsOnlineException() - Constructor for exception org.apache.hadoop.hbase.exceptions.NotAllMetaRegionsOnlineException
default constructor
NotAllMetaRegionsOnlineException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.NotAllMetaRegionsOnlineException
 
notEmpty() - Method in class org.apache.hadoop.hbase.util.ByteRange
 
notEmpty(ByteRange) - Static method in class org.apache.hadoop.hbase.util.ByteRange
 
notEmpty(Collection<T>) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
 
notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
NotServingRegionException - Exception in org.apache.hadoop.hbase.exceptions
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.exceptions.NotServingRegionException
default constructor
NotServingRegionException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.NotServingRegionException
Constructor
NotServingRegionException(byte[]) - Constructor for exception org.apache.hadoop.hbase.exceptions.NotServingRegionException
Constructor
nubCellsRemain - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
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
 
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_DEAD_REGION_SERVERS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
NUM_INTS - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
NUM_LONGS - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
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 class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
NUM_OPS_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
 
NUM_REGION_SERVERS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
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
 
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_PUTS_WITHOUT_WAL - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
NUMBER_OF_PUTS_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_THREADS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
 
NUMBEROFREQUESTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
NUMBEROFROWS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
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
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.HBaseServer
 
NUMDATAINDEXLEVELS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
numEqualPrefixBytes(ByteRange, int) - Method in class org.apache.hadoop.hbase.util.ByteRange
 
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
 
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.getScannerRows_args
number of rows to return
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
 
numValueBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 

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
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
Requests an authentication token for this user and stores it in the user's credentials.
obtainAuthTokenForJob(JobConf) - Method in class org.apache.hadoop.hbase.security.User
Requests an authentication token for this user and stores it in the user's credentials.
obtainRowLock(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Obtain a lock on the given row.
obtainSeqNum() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
Obtain a log sequence number.
obtainServerLoadPB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
obtainToken(Configuration) - 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
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
Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job.
offer(Runnable) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
offer(Runnable, long, TimeUnit) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
offerReadLatency(long, boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
offerWriteLatency(long) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
offline(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Special method, only used by hbck.
OFFLINE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
OFFLINE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
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, MasterAdminProtos.OfflineRegionRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
Offline specified region from master's in-memory state.
offlineRegion(RpcController, MasterAdminProtos.OfflineRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
offlineRegion(RpcController, MasterAdminProtos.OfflineRegionRequest, RpcCallback<MasterAdminProtos.OfflineRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
offlineRegion(RpcController, MasterAdminProtos.OfflineRegionRequest, RpcCallback<MasterAdminProtos.OfflineRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
offlineRegion(RpcController, MasterAdminProtos.OfflineRegionRequest, RpcCallback<MasterAdminProtos.OfflineRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
OffPeakCompactions - Class in org.apache.hadoop.hbase.regionserver.compactions
The class used to track off-peak hours and compactions.
OffPeakCompactions(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.OffPeakCompactions
 
offset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
OFFSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
offsetIntoBlock - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
OLDEST_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.HConstants
Timestamp to use when we want to refer to the oldest cell.
oldestUnexpiredTS - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
oldLogDir - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
 
ON_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
onEviction(BlockCacheKey, SingleSizeCache) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
 
onInsertion(BlockCacheKey, SingleSizeCache) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
 
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.
onlyType - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
 
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 - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
open(FileSystem, CacheConfig, DataBlockEncoding) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Open a Reader for the StoreFile
OPEN_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
OPENED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
 
OpenedRegionHandler - Class in org.apache.hadoop.hbase.master.handler
Handles OPENED region event on Master.
OpenedRegionHandler(Server, AssignmentManager, HRegionInfo, ServerName, int) - Constructor for class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
 
openHRegion(HRegionInfo, HTableDescriptor, HLog, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Open a Region.
openHRegion(HRegionInfo, HTableDescriptor, HLog, Configuration, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Open a Region.
openHRegion(Path, HRegionInfo, HTableDescriptor, HLog, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Open a Region.
openHRegion(Path, HRegionInfo, HTableDescriptor, HLog, Configuration, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Open a Region.
openHRegion(Configuration, FileSystem, Path, HRegionInfo, HTableDescriptor, HLog) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Open a Region.
openHRegion(Configuration, FileSystem, Path, HRegionInfo, HTableDescriptor, HLog, 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(CancelableProgressable) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Open HRegion.
OPENINFO_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
OPENING_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
OPENINGSTATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
OpenMetaHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handles opening of a meta region on a region server.
OpenMetaHandler(Server, RegionServerServices, HRegionInfo, HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.OpenMetaHandler
 
OpenMetaHandler(Server, RegionServerServices, HRegionInfo, HTableDescriptor, int) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.OpenMetaHandler
 
openReader(Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
Opens the file at the current position
openReader(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
Open a reader on the current path
openRegion(RpcController, AdminProtos.OpenRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
 
openRegion(RpcController, AdminProtos.OpenRegionRequest, RpcCallback<AdminProtos.OpenRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
 
openRegion(RpcController, AdminProtos.OpenRegionRequest, RpcCallback<AdminProtos.OpenRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
openRegion(RpcController, AdminProtos.OpenRegionRequest, RpcCallback<AdminProtos.OpenRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
openRegion(AdminProtocol, 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.HRegionServer
Open asynchronously a region or a set of regions on the region server.
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) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
 
OpenRegionHandler(Server, RegionServerServices, HRegionInfo, HTableDescriptor, int) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
 
OpenRegionHandler(Server, RegionServerServices, HRegionInfo, HTableDescriptor, EventType, int) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
 
OpenRootHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handles opening of the root region on a region server.
OpenRootHandler(Server, RegionServerServices, HRegionInfo, HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.OpenRootHandler
 
OpenRootHandler(Server, RegionServerServices, HRegionInfo, HTableDescriptor, int) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.OpenRootHandler
 
openScanner() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
 
openScanner(ByteBuffer, TScan, AsyncMethodCallback<THBaseService.AsyncClient.openScanner_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
openScanner(ByteBuffer, TScan, AsyncMethodCallback<THBaseService.AsyncClient.openScanner_call>) - 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
 
openServer() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Open a previously started server.
openServer() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
 
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
 
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
 
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
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_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
 
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.
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.catalog - package org.apache.hadoop.hbase.catalog
 
org.apache.hadoop.hbase.client - package org.apache.hadoop.hbase.client
Provides HBase Client
org.apache.hadoop.hbase.client.coprocessor - package org.apache.hadoop.hbase.client.coprocessor
Provides client classes for invoking Coprocessor RPC protocols
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.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.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.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.master - package org.apache.hadoop.hbase.generated.master
 
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.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.encoding - package org.apache.hadoop.hbase.io.encoding
 
org.apache.hadoop.hbase.io.hfile - package org.apache.hadoop.hbase.io.hfile
Provides the hbase data+index+metadata file.
org.apache.hadoop.hbase.io.hfile.bucket - package org.apache.hadoop.hbase.io.hfile.bucket
 
org.apache.hadoop.hbase.io.hfile.slab - package org.apache.hadoop.hbase.io.hfile.slab
 
org.apache.hadoop.hbase.ipc - package org.apache.hadoop.hbase.ipc
Tools to help define network clients and servers.
org.apache.hadoop.hbase.mapred - package org.apache.hadoop.hbase.mapred
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility
org.apache.hadoop.hbase.mapreduce - package org.apache.hadoop.hbase.mapreduce
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility
org.apache.hadoop.hbase.mapreduce.hadoopbackport - package org.apache.hadoop.hbase.mapreduce.hadoopbackport
 
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.snapshot - package org.apache.hadoop.hbase.master.snapshot
 
org.apache.hadoop.hbase.metrics - package org.apache.hadoop.hbase.metrics
 
org.apache.hadoop.hbase.metrics.file - package org.apache.hadoop.hbase.metrics.file
 
org.apache.hadoop.hbase.metrics.histogram - package org.apache.hadoop.hbase.metrics.histogram
 
org.apache.hadoop.hbase.monitoring - package org.apache.hadoop.hbase.monitoring
 
org.apache.hadoop.hbase.procedure - package org.apache.hadoop.hbase.procedure
 
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.protobuf.generated - package org.apache.hadoop.hbase.protobuf.generated
 
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.snapshot - package org.apache.hadoop.hbase.regionserver.snapshot
 
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.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.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.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.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.test - package org.apache.hadoop.hbase.util.test
 
org.apache.hadoop.hbase.util.vint - package org.apache.hadoop.hbase.util.vint
 
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
 
OrphanHLogAfterSplitException - Exception in org.apache.hadoop.hbase.exceptions
 
OrphanHLogAfterSplitException() - Constructor for exception org.apache.hadoop.hbase.exceptions.OrphanHLogAfterSplitException
Create this exception without a message
OrphanHLogAfterSplitException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.OrphanHLogAfterSplitException
Create this exception with a message
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
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)
out - Variable in class org.apache.hadoop.hbase.codec.BaseEncoder
 
out - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
out - Static variable in class org.apache.hadoop.hbase.regionserver.DebugPrint
 
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_TABLE - Static variable in class org.apache.hadoop.hbase.mapred.TableOutputFormat
Deprecated. 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.
OWNED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
 
OWNER - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
OWNER_KEY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 

P

P - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'P'
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
 
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.
PAGESIZE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
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
ParallelSeekHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handler to seek storefiles in parallel.
ParallelSeekHandler(KeyValueScanner, KeyValue, long, CountDownLatch) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
 
param - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
parent - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
Tree content/structure used during tokenization
PARENTID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
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(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(Configuration) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperMainServerArg
 
parseCell() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
 
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.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.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
 
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.MultipleColumnPrefixFilter
 
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(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(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
parseFrom(ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
parseFrom(InputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
parseFrom(CodedInputStream) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.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
 
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
 
parseLong(String, long, long) - Static method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
Parse a number and enforce a range.
parseOptions(String[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
 
parsePort(String) - Static method in class org.apache.hadoop.hbase.ServerName
 
parsePort(String) - Static method in class org.apache.hadoop.hbase.util.Addressing
 
parseRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Separate elements of a regionName.
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
 
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().
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.
PASSWORD_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
PASSWORD_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
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 - Static variable in class org.apache.hadoop.hbase.util.CompressionTest
 
PATH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
pathPrefix - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
PATTERN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
PATTERNFLAGS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
pause(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
PayloadCarryingRpcController - Class in org.apache.hadoop.hbase.ipc
Optionally carries Cells across the proxy/service interface down into ipc.
PayloadCarryingRpcController() - Constructor for class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
PayloadCarryingRpcController(CellScanner) - Constructor for class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
PayloadCarryingRpcController(List<CellScannable>) - Constructor for class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
PB_MAGIC - Static variable in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Magic we put ahead of a serialized protobuf message.
peek() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
peek() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Look at the next KeyValue in this scanner, but do not iterate scanner.
peek() - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
 
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.CollectionBackedScanner
 
PENDING_CLOSE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
PENDING_OPEN_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
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.CachedBlock
 
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
 
performCompaction(InternalScanner, Compactor.CellSink, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
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
 
PERMISSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
PERMISSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
PERMISSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
PERMISSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
PERMISSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
PERMISSIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
PERMISSIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
PersistentMetricsTimeVaryingRate - Class in org.apache.hadoop.hbase.metrics
Deprecated. 
PersistentMetricsTimeVaryingRate(String, MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
Deprecated. Constructor - create a new metric
PersistentMetricsTimeVaryingRate(String, MetricsRegistry) - Constructor for class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
Deprecated. Constructor - create a new metric
pingInterval - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
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.exceptions
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.exceptions.PleaseHoldException
 
PleaseHoldException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.PleaseHoldException
 
PleaseHoldException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.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
 
poll() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
 
poll() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlockQueue
 
poll() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
pollLast() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
 
pollLast() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlockQueue
 
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
 
populateQualifier() - 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.HBaseServer
 
port - Static variable in class org.apache.hadoop.hbase.thrift.DemoClient
 
PORT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
PORT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
PORT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
POSITION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
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
 
post(String, String, byte[]) - 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(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(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
 
postAddColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postAddColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the new column family has been created.
postAddColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postAddColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the new column family has been created.
postAddColumnHandler(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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
 
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(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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(ObserverContext<MasterCoprocessorEnvironment>, List<RegionPlan>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Pair<Mutation, Integer>>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Pair<Mutation, Integer>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
This will be called after applying a batch of Mutations on a region.
postBatchMutate(MiniBatchOperationInProgress<Pair<Mutation, Integer>>) - 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
 
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.security.access.AccessController
 
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
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
Deprecated. Use RegionObserver.postCompact(ObserverContext, Store, StoreFile, CompactionRequest) instead
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
Deprecated. use RegionObserver.postCompactSelection(ObserverContext, Store, ImmutableList, CompactionRequest) instead.
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) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
postCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
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.security.access.AccessController
 
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.security.access.AccessController
 
postDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the client deletes a value.
postDelete(Delete, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the column family has been deleted.
postDeleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the column family has been deleted.
postDeleteColumnHandler(byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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.security.access.AccessController
 
postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the deleteTable operation has been requested.
postDeleteTable(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after HMaster deletes a table.
postDeleteTableHandler(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postDisableTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDisableTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the disableTable operation has been requested.
postDisableTable(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDisableTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the disableTable operation has been requested.
postDisableTableHandler(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postEnableTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postEnableTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the enableTable operation has been requested.
postEnableTable(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postEnableTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the enableTable operation has been requested.
postEnableTableHandler(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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.
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
Deprecated. use RegionObserver.preFlush(ObserverContext, Store, InternalScanner) instead.
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(ObserverContext<RegionCoprocessorEnvironment>, Get, List<KeyValue>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postGet(ObserverContext<RegionCoprocessorEnvironment>, Get, List<KeyValue>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the client performs a Get
postGet(Get, List<KeyValue>) - 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
 
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
postLogArchive(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
The WAL has been archived.
postLogArchive(Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
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
 
postModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the column family has been updated.
postModifyColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the column family has been updated.
postModifyColumnHandler(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, byte[], HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after the modifyTable operation has been requested.
postModifyTable(byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called after to modifying a table's properties.
postModifyTableHandler(byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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.security.access.AccessController
 
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
 
postOpenDeployTasks(HRegion, CatalogTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
postOpenDeployTasks(HRegion, CatalogTracker) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
Tasks to perform after region open to complete deploy of region on regionserver
postProcess(HRegion, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
 
postProcess(HRegion, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
The hook to be executed after process().
postPut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postPut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after the client stores a value.
postPut(Put, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postPut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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.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
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
 
postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, byte[], boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, byte[], 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[]) - 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
 
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.security.access.AccessController
 
postSplit(ObserverContext<RegionCoprocessorEnvironment>, HRegion, HRegion) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postSplit(ObserverContext<RegionCoprocessorEnvironment>, HRegion, HRegion) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Deprecated. Use postCompleteSplit() instead
postSplit(HRegion, HRegion) - 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.BaseMasterObserver
 
postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called immediately after an active master instance has completed initialization.
postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
postWALRestore(ObserverContext<RegionCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
postWALRestore(ObserverContext<RegionCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called after a WALEdit replayed for this region.
postWALRestore(HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
postWALWrite(ObserverContext<WALCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
Called after a WALEdit is writen to WAL.
postWALWrite(HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
 
pread - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to adding a new column family to the table.
preAddColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to adding a new column family to the table.
preAddColumnHandler(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - 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
 
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(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Pair<Mutation, Integer>>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Pair<Mutation, Integer>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
This will be called for every batch mutation operation happening at the server.
preBatchMutate(MiniBatchOperationInProgress<Pair<Mutation, Integer>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
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(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 WRITE privileges on the Column Families involved in the bulkLoadHFile request.
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
 
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
 
preCleanupBulkLoad(RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
Authorization security check for SecureBulkLoadProtocol.cleanupBulkLoad()
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.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
 
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
Deprecated. use RegionObserver.preCompact(ObserverContext, Store, InternalScanner, ScanType, CompactionRequest) instead
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) - 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
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
Deprecated. Use RegionObserver.preCompactScannerOpen(ObserverContext, Store, List, ScanType, long, InternalScanner, CompactionRequest) instead.
preCompactScannerOpen(Store, List<StoreFileScanner>, ScanType, long, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
See RegionObserver.preCompactScannerOpen(ObserverContext, Store, List, ScanType, long, InternalScanner, CompactionRequest)
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
Deprecated. Use RegionObserver.preCompactSelection(ObserverContext, Store, List, CompactionRequest) instead
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.
preCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, List<StoreFile>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preCreateCoprocScanner(CompactionRequest, ScanType, long, List<StoreFileScanner>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
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.security.access.AccessController
 
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.security.access.AccessController
 
preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the client deletes a value.
preDelete(Delete, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to deleting the entire column family.
preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to deleting the entire column family.
preDeleteColumnHandler(byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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.security.access.AccessController
 
preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before HMaster deletes a table.
preDeleteTable(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called before HMaster deletes a table.
preDeleteTableHandler(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to disabling a table.
preDisableTable(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to disabling a table.
preDisableTableHandler(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to enabling a table.
preEnableTable(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to enabling a table.
preEnableTableHandler(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[]) - 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
 
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
PREFIX_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
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) - 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) - 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) - 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
This class is created via reflection in DataBlockEncoding enum.
PrefixTreeCodec() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
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
Deprecated. use RegionObserver.preFlush(ObserverContext, Store, InternalScanner) instead
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) - 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
Called before a memstore is flushed to disk and prior to creating the scanner to read from the memstore.
preFlushScannerOpen(Store, KeyValueScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
See RegionObserver.preFlushScannerOpen(ObserverContext, Store, KeyValueScanner, InternalScanner)
preGet(ObserverContext<RegionCoprocessorEnvironment>, Get, List<KeyValue>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preGet(ObserverContext<RegionCoprocessorEnvironment>, Get, List<KeyValue>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the client performs a Get
preGet(Get, List<KeyValue>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preGet(ObserverContext<RegionCoprocessorEnvironment>, Get, List<KeyValue>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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
 
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
 
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
 
preLogArchive(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
The WAL is going to be archived.
preLogArchive(Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
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
 
preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to modifying a column family's attributes.
preModifyColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to modifying a column family's attributes.
preModifyColumnHandler(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, byte[], HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to modifying a table's properties.
preModifyTable(byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
Called prior to modifying a table's properties.
preModifyTableHandler(byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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.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
 
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.TakeSnapshotHandler
 
prepare(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
Does checks on merge inputs.
prepare() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransaction
Does checks on split inputs.
prepareBulkLoad(byte[]) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
prepareBulkLoad(RpcController, SecureBulkLoadProtos.PrepareBulkLoadRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.BlockingInterface
 
prepareBulkLoad(RpcController, SecureBulkLoadProtos.PrepareBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.PrepareBulkLoadResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Interface
 
prepareBulkLoad(RpcController, SecureBulkLoadProtos.PrepareBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.PrepareBulkLoadResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
 
prepareBulkLoad(RpcController, SecureBulkLoadProtos.PrepareBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.PrepareBulkLoadResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Stub
 
prepareBulkLoad(byte[], String) - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.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, byte[], int) - 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, byte[], int) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
 
prepareEncoder(PrefixTreeEncoder, OutputStream, boolean) - Static method in class org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderFactory
helper
prepareEncoding() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
prepare to start a new encoding.
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.DeleteTableHandler
 
prepareWithTableLock() - Method in class org.apache.hadoop.hbase.master.handler.ModifyTableHandler
 
prepareWithTableLock() - Method in class org.apache.hadoop.hbase.master.handler.TableAddFamilyHandler
 
prepareWithTableLock() - Method in class org.apache.hadoop.hbase.master.handler.TableDeleteFamilyHandler
 
prepareWithTableLock() - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
Called from prepare() while holding the table lock.
prepareWithTableLock() - Method in class org.apache.hadoop.hbase.master.handler.TableModifyFamilyHandler
 
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(RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
Authorization check for SecureBulkLoadProtocol.prepareBulkLoad()
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, boolean) - Method in class org.apache.hadoop.hbase.constraint.ConstraintProcessor
 
prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before the client stores a value.
prePut(Put, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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.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
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
 
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
 
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
 
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.DefaultCompactionPolicy
 
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(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.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.security.access.AccessController
 
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 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
 
preStop(String) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
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(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
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
 
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
See RegionObserver.preStoreScannerOpen(ObserverContext, Store, Scan, NavigableSet, KeyValueScanner)
prettyPrint(String) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Use logging.
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(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
 
PREVBALANCEVALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
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)
PREVVALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
preWALRestore(ObserverContext<RegionCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
preWALRestore(ObserverContext<RegionCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
Called before a WALEdit replayed for this region.
preWALRestore(HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
preWALWrite(ObserverContext<WALCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
Called before a WALEdit is writen to WAL.
preWALWrite(HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
 
print(String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
println(String) - Static method in class org.apache.hadoop.hbase.regionserver.DebugPrint
 
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.coprocessor.CoprocessorHost.Environment
Chaining priority
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_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
 
priorityCallQueue - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
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.
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.
ProcedureCoordinatorRpcs - Interface in org.apache.hadoop.hbase.procedure
RPCs for the coordinator to run a barriered procedure with subprocedures executed at distributed members.
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.
process(RpcController, RowProcessorProtos.RowProcessorRequest, RpcCallback<RowProcessorProtos.RowProcessorResult>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
Pass a processor to HRegion 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.MergedRegionHandler
 
process() - Method in class org.apache.hadoop.hbase.master.handler.MetaServerShutdownHandler
 
process() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
 
process() - Method in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
 
process() - Method in class org.apache.hadoop.hbase.master.handler.SplitRegionHandler
 
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(RpcController, RowProcessorProtos.RowProcessorRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService.BlockingInterface
 
process(RpcController, RowProcessorProtos.RowProcessorRequest, RpcCallback<RowProcessorProtos.RowProcessorResult>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService.Interface
 
process(RpcController, RowProcessorProtos.RowProcessorRequest, RpcCallback<RowProcessorProtos.RowProcessorResult>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
 
process(RpcController, RowProcessorProtos.RowProcessorRequest, RpcCallback<RowProcessorProtos.RowProcessorResult>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService.Stub
 
process() - Method in class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
 
process() - Method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
 
process() - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
 
process(long, HRegion, List<KeyValue>, 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>, byte[], ExecutorService, Object[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated. since 0.96 - Use HTableInterface.batch(java.util.List, java.lang.Object[]) instead
processBatch(List<? extends Row>, Object[]) - Method in class org.apache.hadoop.hbase.client.HTable
Parameterized batch processing, allowing varying return types for different Row implementations.
processBatchCallback(List<? extends Row>, byte[], ExecutorService, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.HConnection
Deprecated. since 0.96 - Use HTableInterface.batchCallback(java.util.List, java.lang.Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead
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.
processDeadRegion(HRegionInfo, Result, AssignmentManager, CatalogTracker) - Static method in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
Process a dead region from a dead RS.
processDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
PROCESSED_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
processedCall(int) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
processedCall(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
processEndOfFile() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
If the queue isn't empty, switch to the next one Else if this is a recovered queue, it means we're done! Else we'll just continue to try reading the log file
processFile(Configuration, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
reads a log file and outputs its contents, one transaction at a time, as specified by the currently configured options
processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
This method is called to process the options after they have been parsed.
processRequest(byte[]) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
 
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
Performs atomic multiple reads and writes on a given row.
processRowsWithLocks(RowProcessor<?, ?>, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Performs atomic multiple reads and writes on a given row.
processServerShutdown(ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Process shutdown server removing any assignments.
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
 
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.
ProtobufRpcClientEngine - Class in org.apache.hadoop.hbase.ipc
 
ProtobufRpcClientEngine(Configuration, String) - Constructor for class org.apache.hadoop.hbase.ipc.ProtobufRpcClientEngine
 
ProtobufUtil - Class in org.apache.hadoop.hbase.protobuf
Protobufs utility.
PROTOCOL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
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(HRegionInfo) - Method in interface org.apache.hadoop.hbase.tool.Canary.Sink
 
publishReadFailure(HRegionInfo, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.tool.Canary.Sink
 
publishReadFailure(HRegionInfo) - Method in class org.apache.hadoop.hbase.tool.Canary.StdOutSink
 
publishReadFailure(HRegionInfo, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.tool.Canary.StdOutSink
 
publishReadTiming(HRegionInfo, HColumnDescriptor, long) - Method in interface org.apache.hadoop.hbase.tool.Canary.Sink
 
publishReadTiming(HRegionInfo, HColumnDescriptor, long) - Method in class org.apache.hadoop.hbase.tool.Canary.StdOutSink
 
purgeTimeout - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
PURPOSE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
pushMetric(MetricsRecord) - Method in class org.apache.hadoop.hbase.metrics.ExactCounterMetric
Deprecated.  
pushMetric(MetricsRecord) - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
pushMetric(MetricsRecord) - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
Deprecated.  
pushMetric(MetricsRecord) - Method in class org.apache.hadoop.hbase.metrics.MetricsString
Deprecated.  
pushMetric(MetricsRecord) - Method in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
Deprecated. Push updated metrics to the mr.
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(Put) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Puts some data in the table.
put(List<Put>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Puts some data in the table, in batch.
put(byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
The put request will be buffered by its corresponding buffer queue.
put(byte[], List<Put>) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
The puts request will be buffered by their corresponding buffer queue.
put(byte[], Put, int) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
The put request will be buffered by its corresponding buffer queue.
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, 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(byte[], int) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
Put the magic record out to the specified byte array position.
put(Put) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
put(Put, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
put(Put[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Perform a batch put with no pre-specified locks
put(K, V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Insert a key-value mapping into the map.
put(String, String, byte[]) - 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(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(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<THBaseService.AsyncClient.put_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
put(ByteBuffer, TPut, AsyncMethodCallback<THBaseService.AsyncClient.put_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
 
put - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
the TPut to put if the check succeeds
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 - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
the TPut to put
put(ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
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(K, V) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
PUT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
 
PUT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
 
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
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
putBack(KeyValue) - Method in class org.apache.hadoop.hbase.rest.ResultGenerator
 
putBack(KeyValue) - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
 
putBack(KeyValue) - 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
 
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.
putBytes(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put bytes at the specified byte array position.
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)
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(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Put an int value out to the specified byte array position.
putLong(OutputStream, long, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
 
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.
putMultiple(ByteBuffer, List<TPut>, AsyncMethodCallback<THBaseService.AsyncClient.putMultiple_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
 
putMultiple(ByteBuffer, List<TPut>, AsyncMethodCallback<THBaseService.AsyncClient.putMultiple_call>) - 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
puts - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
a list of TPuts to commit
putsFromThrift(List<TPut>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
Converts multiple TPuts (Thrift) into a list of Puts (HBase).
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.
PutSortReducer - Class in org.apache.hadoop.hbase.mapreduce
Emits sorted Puts.
PutSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.PutSortReducer
 
putTable(HTableInterface) - Method in class org.apache.hadoop.hbase.client.HTablePool
Deprecated.  

Q

QOS_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
 
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.checkAndPut_args
column qualifier to check
QUALIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
QUALIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
QUALIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
QUALIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
QUALIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
QUALIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
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
 
QUALIFIERS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
qualifierTokenizer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
QUALIFIERVALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
qualifierWriter - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
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_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
 
queueIncrement(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
queueIncrements(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
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

R

R - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'R'
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.
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 interface org.apache.hadoop.hbase.master.LoadBalancer
Get a random region server from the list
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.
RANGE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
raw() - Method in class org.apache.hadoop.hbase.client.Result
Return the array of KeyValues backing this Result instance.
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.DataInputInputStream
 
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(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.Reference
Read a Reference from FileSystem.
read() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection.PingInputStream
Read a byte from the stream.
read(byte[], int, int) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection.PingInputStream
Read bytes into a buffer starting from offset off Send a ping if timeout on read.
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 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.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.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.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.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.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.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 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.TScan
 
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_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
READ_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
READ_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
 
readAllEntriesToReplicateOrNextFile(boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
Read all the entries from the current log files and retain those that need to be replicated.
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.HBaseServer.Connection
Read off the wire.
readBlock(long, long, boolean, boolean, boolean, BlockType) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader
 
readBlock(long, long, boolean, boolean, boolean, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
Read in a file block.
readBlockData(long, long, int, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
Reads the block at the given offset in the file with the given on-disk size and uncompressed size.
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.
reader - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
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.hfile.BlockCacheColumnFamilySummary
 
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.TableSplit
Deprecated.  
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.master.RegionState
Deprecated. Writables are going away
readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog.Entry
 
readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
 
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
 
readFrom(Class<ProtobufMessageHandler>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class org.apache.hadoop.hbase.rest.provider.consumer.ProtobufMessageBodyConsumer
 
readFromStream(FSDataInputStream, long) - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
Reads a file trailer from the given file.
readLock(byte[]) - Method in interface org.apache.hadoop.hbase.InterProcessReadWriteLock
Obtain a reader lock containing given metadata.
readLock(byte[], String) - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
 
readLock(byte[], 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 reader lock containing given metadata.
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.
readMyEphemeralNodeOnDisk() - Static method in class org.apache.hadoop.hbase.ZNodeClearer
read the content of znode file, expects a single line.
readNextAndSetPosition(HLog.Entry[], int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
Get the next entry, returned and also added in the array
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.
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
 
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(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.protobuf.generated.HBaseProtos.RegionLoad
 
READREQUESTSCOUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
readResponse() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
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
 
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
Reads a zero-compressed encoded long from input stream and returns it.
readWithExtra(InputStream, byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Read from an input stream.
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
 
REALUSER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
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.
reapAllLocks() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessReadLock
 
reapAllLocks() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessWriteLock
Referred in zk recipe as "Revocable Shared Locks with Freaking Laser Beams" (http://zookeeper.apache.org/doc/trunk/recipes.html).
reapAllTableWriteLocks() - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
 
reapAllTableWriteLocks() - Method in class org.apache.hadoop.hbase.master.TableLockManager
Force releases all table write locks and lock attempts even if this thread does not own the lock.
REASON_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
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
receiveReachedGlobalBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
Callback for the member rpcs to call when the global barrier has been reached.
receiveSpan(Span) - Method in class org.apache.hadoop.hbase.trace.HBaseLocalFileSpanReceiver
 
reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
reconstruct(PrefixTreeBlockMeta, Tokenizer, boolean) - 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
 
RecoverableZooKeeper - Class in org.apache.hadoop.hbase.zookeeper
A zookeeper that can handle 'recoverable' errors.
RecoverableZooKeeper(String, int, Watcher, int, int) - Constructor for class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
RecoverableZooKeeper(String, int, Watcher, int, int, String) - Constructor for class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
RECOVERED_EDITS_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
 
RECOVERED_LOG_TMPFILE_SUFFIX - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.HLog
 
recoveredEdits(String, String) - Method in interface org.apache.hadoop.hbase.util.FSVisitor.RecoveredEditsVisitor
 
recoverFileLease(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.util.FSHDFSUtils
 
recoverFileLease(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.util.FSMapRUtils
 
recoverFileLease(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.util.FSUtils
Recover file lease.
recv_checkAndDelete() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.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_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_exists() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_get() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
recv_getMultiple() - 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_increment() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.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
 
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
Deprecated. 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(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
 
RedundantKVGenerator - Class in org.apache.hadoop.hbase.util.test
Generate list of key values which are very useful to test data block encoding and compression.
RedundantKVGenerator() - Constructor for class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
Default constructor, assumes all parameters from class constants.
RedundantKVGenerator(Random, int, int, int, int, int, int, float, float, int, int, int, int, float, int, int) - Constructor for class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
Various configuration options for generating key values
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. 
REFERENCE - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Reference size is 8 bytes on 64-bit, 4 bytes on 32-bit
ReferenceRegionHFilesTask - Class in org.apache.hadoop.hbase.snapshot
Reference all the hfiles in a region for a snapshot.
ReferenceRegionHFilesTask(HBaseProtos.SnapshotDescription, ForeignExceptionDispatcher, Path, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.snapshot.ReferenceRegionHFilesTask
Reference all the files in the given region directory
ReferenceServerWALsTask - Class in org.apache.hadoop.hbase.snapshot
Reference all the WAL files under a server's WAL directory
ReferenceServerWALsTask(HBaseProtos.SnapshotDescription, ForeignExceptionDispatcher, Path, Configuration, FileSystem) - Constructor for class org.apache.hadoop.hbase.snapshot.ReferenceServerWALsTask
 
ReflectionUtils - Class in org.apache.hadoop.hbase.util
 
ReflectionUtils() - Constructor for class org.apache.hadoop.hbase.util.ReflectionUtils
 
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() - 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.
refreshCacheFromWritable(byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
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, int) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
Constructor
regexStringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
RegexStringType byte array
region - Variable in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
The region configured for this split policy.
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
REGION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
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_MERGES_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Temporary subdirectory of the region directory used for merges.
REGION_NAME_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
 
REGION_PROTOCOL_CLASS - Static variable in class org.apache.hadoop.hbase.client.HConnectionManager
Parameter name for what admin protocol to use.
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_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_SPLITS_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Temporary subdirectory of the region directory used for splits.
REGIONA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
REGIONA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
RegionAlreadyInTransitionException - Exception in org.apache.hadoop.hbase.exceptions
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.exceptions.RegionAlreadyInTransitionException
 
REGIONB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
REGIONB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
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 HRegion.
RegionCoprocessorHost(HRegion, 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(HConnection, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
 
regionDirPattern - Static variable in class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
 
RegionException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when something happens related to region handling.
RegionException() - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionException
default constructor
RegionException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionException
Constructor
REGIONID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
REGIONINFO_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
REGIONINFO_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
REGIONINFO_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
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
RegionListTmpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
RegionListTmpl(TemplateManager) - 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(HBaseProtos.RegionLoad) - Constructor for class org.apache.hadoop.hbase.RegionLoad
 
regionLoadPB - Variable in class org.apache.hadoop.hbase.RegionLoad
 
REGIONLOADS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
RegionMergeTransaction - Class in org.apache.hadoop.hbase.regionserver
Executes region merge as a "transaction".
RegionMergeTransaction(HRegion, HRegion, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
Constructor
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
REGIONNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
RegionObserver - Interface in org.apache.hadoop.hbase.coprocessor
Coprocessors implement this interface to observe and mediate client actions on the region.
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.RegionStates
A region is offline, won't be in transition any more.
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.RegionStates
A region is online, won't be in transition any more.
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
 
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
 
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
 
RegionScanner - Interface in org.apache.hadoop.hbase.regionserver
RegionScanner describes iterators over rows in an HRegion.
REGIONSERVER - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
region server process name
REGIONSERVER_CONF - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
region server configuration 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_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for port region server listens on.
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
 
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
 
RegionServerListTmpl - Class in org.apache.hadoop.hbase.tmpl.master
 
RegionServerListTmpl(TemplateManager) - 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
 
RegionServerObserver - Interface in org.apache.hadoop.hbase.coprocessor
 
regionServerReport(RpcController, RegionServerStatusProtos.RegionServerReportRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
regionServerReport(RpcController, RegionServerStatusProtos.RegionServerReportRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
 
regionServerReport(RpcController, RegionServerStatusProtos.RegionServerReportRequest, RpcCallback<RegionServerStatusProtos.RegionServerReportResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.Interface
 
regionServerReport(RpcController, RegionServerStatusProtos.RegionServerReportRequest, RpcCallback<RegionServerStatusProtos.RegionServerReportResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
regionServerReport(RpcController, RegionServerStatusProtos.RegionServerReportRequest, RpcCallback<RegionServerStatusProtos.RegionServerReportResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.Stub
 
RegionServerRunningException - Exception in org.apache.hadoop.hbase.exceptions
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.exceptions.RegionServerRunningException
Default Constructor
RegionServerRunningException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionServerRunningException
Constructs the exception and supplies a string as the message
RegionServerServices - Interface in org.apache.hadoop.hbase.regionserver
Services provided by HRegionServer
RegionServerSnapshotManager - Class in org.apache.hadoop.hbase.regionserver.snapshot
This manager class handles the work dealing with snapshots for a HRegionServer.
RegionServerSnapshotManager(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
Create a default snapshot handler - uses a zookeeper based member controller.
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.HMaster
 
regionServerStartup(RpcController, RegionServerStatusProtos.RegionServerStartupRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
 
regionServerStartup(RpcController, RegionServerStatusProtos.RegionServerStartupRequest, RpcCallback<RegionServerStatusProtos.RegionServerStartupResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.Interface
 
regionServerStartup(RpcController, RegionServerStatusProtos.RegionServerStartupRequest, RpcCallback<RegionServerStatusProtos.RegionServerStartupResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
regionServerStartup(RpcController, RegionServerStatusProtos.RegionServerStartupRequest, RpcCallback<RegionServerStatusProtos.RegionServerStartupResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.Stub
 
RegionServerStatusProtocol - Interface in org.apache.hadoop.hbase
Protocol that a RegionServer uses to communicate its status to the Master.
RegionServerStatusProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.GetLastFlushedSequenceIdRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.GetLastFlushedSequenceIdRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.GetLastFlushedSequenceIdResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.GetLastFlushedSequenceIdResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerReportRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerReportRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerReportRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerReportResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerReportResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerReportResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerStartupRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerStartupRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerStartupRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerStartupResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerStartupResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerStartupResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerStatusService - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerStatusService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
RegionServerStatusProtos.RegionServerStatusService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerStatusService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.RegionServerStatusService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.ReportRSFatalErrorRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.ReportRSFatalErrorResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStatusProtos.ReportRSFatalErrorResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RegionServerStoppedException - Exception in org.apache.hadoop.hbase.exceptions
Thrown by the region server when it is in shutting down state.
RegionServerStoppedException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionServerStoppedException
 
RegionServerTracker - Class in org.apache.hadoop.hbase.zookeeper
Tracks the online region servers via ZK.
RegionServerTracker(ZooKeeperWatcher, Abortable, ServerManager) - Constructor for class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
 
REGIONSINTRANSITION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
regionsInTransitionInRS - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
REGIONSPECIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
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.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.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, long, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionState
 
RegionState.State - Enum in org.apache.hadoop.hbase.master
 
REGIONSTATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
RegionStates - Class in org.apache.hadoop.hbase.master
Region state accountant.
REGIONTOFLUSH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
RegionTooBusyException - Exception in org.apache.hadoop.hbase.exceptions
Thrown by a region server if it will block and wait to serve a request.
RegionTooBusyException() - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionTooBusyException
default constructor
RegionTooBusyException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionTooBusyException
Constructor
RegionTransition - Class in org.apache.hadoop.hbase
Current state of a region in transition.
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(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
 
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.protobuf.generated.AccessControlProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.Tracing
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos
 
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.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
 
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
 
registerListener(EventType, EventHandler.EventHandlerListener) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
Subscribe to updates before and after processing instances of EventType.
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.
registerRegionServerListener(ZooKeeperListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
 
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 to be available for handling MasterAdminProtos.MasterAdminService.BlockingInterface.execMasterService(com.google.protobuf.RpcController, org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest) calls.
registerService(Service) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Registers a new protocol buffer Service subclass as a coprocessor endpoint to be available for handling HRegion.execService(com.google.protobuf.RpcController, org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall)} calls.
registerWALActionsListener(WALActionsListener) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
registers WALActionsListener
registry - Variable in class org.apache.hadoop.hbase.metrics.HBaseInfo
Deprecated.  
registry - Variable in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
Deprecated.  
registryLength - Variable in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
Deprecated.  
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 class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
Releases resources used by this writer.
release() - Method in interface org.apache.hadoop.hbase.master.TableLockManager.TableLock
Release the lock already held.
release() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Release the lock.
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.
releaseHTableInterface(HTableInterface) - Method in class org.apache.hadoop.hbase.client.HTableFactory
 
releaseHTableInterface(HTableInterface) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
Release the HTable resource represented by the table.
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.
releaseRowLock(Integer) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Release the row lock!
releaseTableLock() - Method in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
 
releaseTableLock() - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
releaseTableLock() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
reloadZkWatcher() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
Closes the current ZKW (if not null) and creates a new one
relocateRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
Find the location of the region of tableName that row lives in, ignoring any value that might be in the cache.
remainingCapacity() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
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
remoteId - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
remotePort - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
 
RemoteWithExtrasException - Exception in org.apache.hadoop.hbase.ipc
An 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(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(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Deletes the mapping for the specified key if it exists.
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(byte[]) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
remove(String) - 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(String) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
 
remove(R) - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
remove(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
remove(K, V) - Method in class org.apache.hadoop.hbase.util.PoolMap
 
remove(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
remove(Object) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
removeAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
removeAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
removeAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
removeAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
removeAttributes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
removeAttributes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
removeAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
removeAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
removeBackupMasters(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
removeCell(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
removeClosedRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
When a region is closed, it should be removed from the regionsToReopen
removeColumn(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
removeColumn(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
removeColumnFamilies(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
removeColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
removeColumnValue(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
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(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
removeConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Remove a coprocessor from those set on the table
removeCoprocessors(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
removeDeadServers(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
removeEnablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
If the table is found in ENABLING state the inmemory state is removed.
removeEntry(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
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
removeFamilyPath(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
removeFamilyPath(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
removeFamilyScope(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
removeFilters(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
removeFromOnlineRegions(HRegion, ServerName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
removeFuzzyKeysData(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
removeGet(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
removeKeyFromZK(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
removeLiveNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
removeLiveServers(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
removeLogFromList(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Remove a log from the list of hlogs in zookeeper
removeMapEntries(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
removeMapEntry(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
removeMasterCoprocessors(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
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.
removeMetrics(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
removeMutationRequest(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
removeNonReplicableEdits(WALEdit) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
We only want KVs that are scoped other than local
removeOpenInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
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 class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Remove the peer from zookeeper.
removePermission(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
removePermission(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
removePermissions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
removePermissions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
removeQualifierValue(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
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
removeRegionInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
removeRegionLoads(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
removeRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
removeRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
removeRegionsInTransition(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
removeResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
removeResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
removeResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
removeRootPath(Path, Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Checks for the presence of the root path (using the provided conf object) in the given path.
removeRows(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
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.
removeServerFromDrainList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
removeShutdownHook(Runnable) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
 
removeSnapshots(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
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
 
removeTableSchema(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
removeTrace(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
removeValues(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
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.BackupMasterListTmpl
 
render(Writer, HMaster, HBaseAdmin) - 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, 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) - 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.BackupMasterListTmpl.Intf
 
renderNoFlush(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterListTmpl
 
renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterListTmplImpl
 
renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.Intf
 
renderNoFlush(Writer, HMaster, HBaseAdmin) - 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.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) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
 
renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmplImpl
 
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
 
repeat(char, int) - Static method in class org.apache.hadoop.hbase.util.Strings
 
replaceValue(V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Replace the value of this entry.
replayRecoveredEditsIfAny(Path, Map<byte[], Long>, CancelableProgressable, MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Read the edits log put under this region by wal log splitting process.
replicateEntries(HLog.Entry[]) - 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(HLog.Entry[]) - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSinkService
Carry on the list of log entries down to the sink
replicateLogEntries(HLog.Entry[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
Carry on the list of log entries down to the sink
replicateWALEntry(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
 
replicateWALEntry(RpcController, AdminProtos.ReplicateWALEntryRequest, RpcCallback<AdminProtos.ReplicateWALEntryResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
 
replicateWALEntry(RpcController, AdminProtos.ReplicateWALEntryRequest, RpcCallback<AdminProtos.ReplicateWALEntryResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
replicateWALEntry(RpcController, AdminProtos.ReplicateWALEntryRequest, RpcCallback<AdminProtos.ReplicateWALEntryResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
replicateWALEntry(AdminProtocol, HLog.Entry[]) - Static method in class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
A helper to replicate a list of HLog entries using admin protocol.
replicateWALEntry(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Replicate WAL entries on the region server.
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_ENABLE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
REPLICATION_LOG_DIR - Static variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
 
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_GLOBAL - Static variable in class org.apache.hadoop.hbase.HConstants
Scope tag for globally scoped data.
REPLICATION_SCOPE_GLOBAL_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.ScopeType
 
REPLICATION_SCOPE_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
Scope tag for locally scoped data.
REPLICATION_SCOPE_LOCAL_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.ScopeType
 
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_SERVICE_CLASSNAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
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.
ReplicationHLogReaderManager - Class in org.apache.hadoop.hbase.replication.regionserver
Wrapper class around HLog to help manage the implementation details such as compression.
ReplicationHLogReaderManager(FileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
Creates the helper but doesn't open any file Use setInitialPosition after using the constructor if some content needs to be skipped
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
 
ReplicationPeer - Class in org.apache.hadoop.hbase.replication
This class acts as a wrapper for all the objects used to identify and communicate with remote peers and is responsible for answering to expired sessions and re-establishing the ZK connections.
ReplicationPeer(Configuration, String, String) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeer
Constructor that takes all the objects required to communicate with the specified peer, except for the region server addresses.
ReplicationPeer.PeerStateTracker - Class in org.apache.hadoop.hbase.replication
Tracker for state of this peer
ReplicationPeer.PeerStateTracker(String, ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeer.PeerStateTracker
 
ReplicationProtbufUtil - Class in org.apache.hadoop.hbase.protobuf
 
ReplicationProtbufUtil() - Constructor for class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
 
replicationQueue - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
replication related queue;
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
 
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
 
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(ReplicationZookeeper, Configuration, Stoppable, FileSystem, AtomicBoolean, Path, Path) - 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
ReplicationSourceManager.OtherRegionServerWatcher - Class in org.apache.hadoop.hbase.replication.regionserver
Watcher used to be notified of the other region server's death in the local cluster.
ReplicationSourceManager.OtherRegionServerWatcher(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager.OtherRegionServerWatcher
Construct a ZooKeeper event listener.
ReplicationSourceManager.PeersWatcher - Class in org.apache.hadoop.hbase.replication.regionserver
Watcher used to follow the creation and deletion of peer clusters.
ReplicationSourceManager.PeersWatcher(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager.PeersWatcher
Construct a ZooKeeper event listener.
ReplicationSourceService - Interface in org.apache.hadoop.hbase.regionserver
A source for a replication stream has to expose this service.
ReplicationStateImpl - Class in org.apache.hadoop.hbase.replication
ReplicationStateImpl is responsible for maintaining the replication state znode.
ReplicationStateImpl(ZooKeeperWatcher, String, Abortable, AtomicBoolean) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationStateImpl
 
ReplicationStateInterface - Interface in org.apache.hadoop.hbase.replication
This provides an interface for getting and setting the replication state of a cluster.
ReplicationZookeeper - Class in org.apache.hadoop.hbase.replication
This class serves as a helper for all things related to zookeeper in replication.
ReplicationZookeeper(Abortable, Configuration, ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Constructor used by clients of replication (like master and HBase clients)
ReplicationZookeeper(Server, AtomicBoolean) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Constructor used by region servers, connects to the peer cluster right away.
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.
reportCompactionRequestEnd(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
reportCompactionRequestStart(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
REPORTENDTIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
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
 
reportRSFatalError(RpcController, RegionServerStatusProtos.ReportRSFatalErrorRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
reportRSFatalError(RpcController, RegionServerStatusProtos.ReportRSFatalErrorRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
 
reportRSFatalError(RpcController, RegionServerStatusProtos.ReportRSFatalErrorRequest, RpcCallback<RegionServerStatusProtos.ReportRSFatalErrorResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.Interface
 
reportRSFatalError(RpcController, RegionServerStatusProtos.ReportRSFatalErrorRequest, RpcCallback<RegionServerStatusProtos.ReportRSFatalErrorResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
 
reportRSFatalError(RpcController, RegionServerStatusProtos.ReportRSFatalErrorRequest, RpcCallback<RegionServerStatusProtos.ReportRSFatalErrorResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.Stub
 
REPORTSTARTTIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
request - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
 
REQUEST_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
REQUEST_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
requestCompaction(HRegion, String) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
 
requestCompaction(HRegion, String, List<Pair<CompactionRequest, Store>>) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
 
requestCompaction(HRegion, Store, String, CompactionRequest) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
 
requestCompaction(HRegion, String, int, List<Pair<CompactionRequest, Store>>) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
 
requestCompaction(HRegion, Store, String, int, CompactionRequest) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
 
requestCompaction(HRegion, String) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestCompaction(HRegion, String, List<Pair<CompactionRequest, Store>>) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestCompaction(HRegion, Store, String, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestCompaction(HRegion, String, int, List<Pair<CompactionRequest, Store>>) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestCompaction(HRegion, Store, String, int, CompactionRequest) - 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() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
requestCompaction(int, CompactionRequest) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
RequestContext - Class in org.apache.hadoop.hbase.ipc
Represents client information (authenticated username, remote address, protocol) for the currently executing request within a RPC server handler thread.
RequestConverter - Class in org.apache.hadoop.hbase.protobuf
Helper utility to build protocol buffer requests, or build components for protocol buffer requests.
requestedSize() - Method in exception org.apache.hadoop.hbase.io.hfile.bucket.CacheFullException
 
requestFlush(HRegion) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
Tell the listener the cache needs to be flushed.
REQUESTPARAM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
requestRegionsMerge(HRegion, HRegion, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
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(KeyValue, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Similar to KeyValueScanner.seek(org.apache.hadoop.hbase.KeyValue) (or KeyValueScanner.reseek(org.apache.hadoop.hbase.KeyValue) 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(KeyValue, boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Similar to KeyValueScanner.seek(org.apache.hadoop.hbase.KeyValue) (or KeyValueScanner.reseek(org.apache.hadoop.hbase.KeyValue) 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(KeyValue, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
 
requestSeek(KeyValue, 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(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
requestSplit(HRegion, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
reseek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
This function is identical to the KeyValueHeap.seek(KeyValue) function except that scanner.seek(seekKey) is changed to scanner.reseek(seekKey).
reseek(KeyValue) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Reseek the scanner at or after the specified KeyValue.
reseek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
Move forward on the sub-lists set previously by seek.
reseek(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
Do a reseek to the required row.
reseek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
reseek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
reseek(KeyValue) - 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(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Reseek to or just before the passed key.
reseekTo(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
 
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.FilterWrapper
 
reset() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
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.io.hfile.bucket.BucketCacheStats
 
reset() - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
reset() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
reset - Variable in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
Deprecated.  
reset() - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
Resets the Matcher
reset() - Static method in class org.apache.hadoop.hbase.regionserver.DebugPrint
 
reset() - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
Called between rows.
reset() - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
 
reset() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Reader
 
reset() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
reset() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
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.
resetBuffer() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
 
resetBuffer() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
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
 
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.
resetMinMaxAvg() - Method in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
Deprecated. Rollover to a new interval NOTE: does not reset numOps.
resetRpcTimeout() - Static method in class org.apache.hadoop.hbase.ipc.HBaseClientRPC
 
resetScannerStack(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
resetState() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
 
resetThreadReadPoint(MultiVersionConsistencyControl) - Static method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
Set the thread MVCC read point to whatever the current read point is in this particular instance of MVCC.
resetThreadReadPoint() - Static method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
Set the thread MVCC read point to 0 (include everything).
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.
RESIGNED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
 
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.HBaseServer.Call
 
responder - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
response - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
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
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.HBaseServer.Connection
 
rest_jsp - Class in org.apache.hadoop.hbase.generated.rest
 
rest_jsp() - Constructor for class org.apache.hadoop.hbase.generated.rest.rest_jsp
 
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.
restoreEdit(Store, KeyValue) - 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 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(RpcController, MasterAdminProtos.RestoreSnapshotRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
Execute Restore/Clone snapshot operation.
restoreSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Restore the specified snapshot
restoreSnapshot(RpcController, MasterAdminProtos.RestoreSnapshotRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
restoreSnapshot(RpcController, MasterAdminProtos.RestoreSnapshotRequest, RpcCallback<MasterAdminProtos.RestoreSnapshotResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
restoreSnapshot(RpcController, MasterAdminProtos.RestoreSnapshotRequest, RpcCallback<MasterAdminProtos.RestoreSnapshotResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
restoreSnapshot(RpcController, MasterAdminProtos.RestoreSnapshotRequest, RpcCallback<MasterAdminProtos.RestoreSnapshotResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
RestoreSnapshotException - Exception in org.apache.hadoop.hbase.exceptions
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.exceptions.RestoreSnapshotException
 
RestoreSnapshotException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.exceptions.RestoreSnapshotException
 
RestoreSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RestoreSnapshotException
 
RestoreSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.RestoreSnapshotException
 
RestoreSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
Handler to Restore a snapshot.
RestoreSnapshotHandler(MasterServices, HBaseProtos.SnapshotDescription, HTableDescriptor) - 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, HBaseProtos.SnapshotDescription, Path, HTableDescriptor, Path, ForeignExceptionDispatcher) - 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 META after restore.
RestoreSnapshotHelper.RestoreMetaChanges() - Constructor for class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
 
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.
RESTVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
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.raw().
Result(KeyValue[]) - Constructor for class org.apache.hadoop.hbase.client.Result
Instantiate a Result with the specified array of KeyValues.
Result(List<? extends Cell>) - Constructor for class org.apache.hadoop.hbase.client.Result
Instantiate a Result with the specified List of KeyValues.
RESULT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
RESULT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
RESULT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
RESULT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
RESULT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
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).
RESULTSIZEBYTES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
resume(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
resumeEncoding() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Resumes encoding of the stream.
retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
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
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
 
rethrowException() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTask
 
retransitionNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Retransitions an existing unassigned node for the specified region which is currently in the OPENING state to be in the OPENING state.
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(List<Throwable>, List<Row>, List<String>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
retrievePassword(AuthenticationTokenIdentifier) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
RETRY_BACKOFF - Static variable in class org.apache.hadoop.hbase.HConstants
This is a retry backoff multiplier table similar to the BSD TCP syn backoff table, a bit more aggressive than simple exponential backoff.
RetryCounter - Class in org.apache.hadoop.hbase.util
 
RetryCounter(int, int, TimeUnit) - Constructor for class org.apache.hadoop.hbase.util.RetryCounter
 
RetryCounterFactory - Class in org.apache.hadoop.hbase.util
 
RetryCounterFactory(int, int) - Constructor for class org.apache.hadoop.hbase.util.RetryCounterFactory
 
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
 
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
 
ReversibleCellScanner - Interface in org.apache.hadoop.hbase.codec.prefixtree.scanner
An extension of CellScanner indicating the scanner supports iterating backwards through cells.
revoke(RpcController, AccessControlProtos.RevokeRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface
 
revoke(RpcController, AccessControlProtos.RevokeRequest, RpcCallback<AccessControlProtos.RevokeResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Interface
 
revoke(RpcController, AccessControlProtos.RevokeRequest, RpcCallback<AccessControlProtos.RevokeResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
 
revoke(RpcController, AccessControlProtos.RevokeRequest, RpcCallback<AccessControlProtos.RevokeResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Stub
 
revoke(AccessControlProtos.AccessControlService.BlockingInterface, String, byte[], byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A utility used to revoke a user some permissions.
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
rewindThenToList(ByteBuffer, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
RIT_COUNT_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
RIT_COUNT_OVER_THRESHOLD_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
RIT_OLDEST_AGE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
rollback(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
rollback(Server, RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
 
rollback(Server, RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransaction
 
rollback(KeyValue) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Removes a kv 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.
rollHLogWriter(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Roll the log writer.
rollMetricsPeriod() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
rollWALWriter(RpcController, AdminProtos.RollWALWriterRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
 
rollWALWriter(RpcController, AdminProtos.RollWALWriterRequest, RpcCallback<AdminProtos.RollWALWriterResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
 
rollWALWriter(RpcController, AdminProtos.RollWALWriterRequest, RpcCallback<AdminProtos.RollWALWriterResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
rollWALWriter(RpcController, AdminProtos.RollWALWriterRequest, RpcCallback<AdminProtos.RollWALWriterResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
rollWALWriter(RpcController, AdminProtos.RollWALWriterRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Roll the WAL writer of the region server.
rollWriter() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
Roll the log writer.
rollWriter(boolean) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
Roll the log writer.
root - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
ROOT_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
A KeyValue.KVComparator for -ROOT- catalog table KeyValues.
ROOT_KEY_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
A KeyValue.KVComparator for -ROOT- catalog table KeyValue keys.
ROOT_REGIONINFO - Static variable in class org.apache.hadoop.hbase.HRegionInfo
HRegionInfo for root region
ROOT_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
The root table's name.
ROOT_TABLEDESC - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Table descriptor for -ROOT- catalog table
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.
rootDir - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
rootDir - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
 
ROOTINDEXSIZEKB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
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 interface org.apache.hadoop.hbase.master.LoadBalancer
Perform a Round Robin assignment of regions.
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 - Interface in org.apache.hadoop.hbase.client
Has a row.
row - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
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.checkAndPut_args
row to check
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
ROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
ROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
ROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
ROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
ROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
ROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
 
ROW_KEYS_PARAM_NAME - Static variable in class org.apache.hadoop.hbase.rest.MultiRowResource
 
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
 
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
 
rowCount(byte[], 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
Deprecated. 
RowCounter() - Constructor for class org.apache.hadoop.hbase.mapred.RowCounter
Deprecated.  
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.
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
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.
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
 
ROWPROCESSORCLASSNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
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
 
ROWPROCESSORINITIALIZERMESSAGE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
ROWPROCESSORINITIALIZERMESSAGENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
RowProcessorProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
RowProcessorProtos.RowProcessorRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
RowProcessorProtos.RowProcessorRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RowProcessorProtos.RowProcessorRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RowProcessorProtos.RowProcessorResult - Class in org.apache.hadoop.hbase.protobuf.generated
 
RowProcessorProtos.RowProcessorResult.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RowProcessorProtos.RowProcessorResultOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RowProcessorProtos.RowProcessorService - Class in org.apache.hadoop.hbase.protobuf.generated
 
RowProcessorProtos.RowProcessorService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
 
RowProcessorProtos.RowProcessorService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RowProcessorProtos.RowProcessorService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RowProcessorProtos.RowProcessorService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
 
ROWPROCESSORRESULT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
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) - Constructor for class org.apache.hadoop.hbase.rest.RowResource
Constructor
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 Hbase RowResult object.
rowResultFromHBase(Result) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
 
RowResultGenerator - Class in org.apache.hadoop.hbase.rest
 
RowResultGenerator(String, RowSpec, Filter) - Constructor for class org.apache.hadoop.hbase.rest.RowResultGenerator
 
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) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
 
rowTokenizer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
rowToStr(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
 
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_CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
 
RPC_ENGINE_PROP - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServerRPC
Configuration key for the RpcServerEngine implementation to load to handle connection protocols.
RPC_HEADER - Static variable in class org.apache.hadoop.hbase.HConstants
The first four bytes of Hadoop RPC connections
RpcCallContext - Interface in org.apache.hadoop.hbase.ipc
 
RpcClientEngine - Interface in org.apache.hadoop.hbase.ipc
An RPC implementation for the client
RPCProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.CellBlockMeta - Class in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.CellBlockMeta.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.CellBlockMetaOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.ConnectionHeader - Class in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.ConnectionHeader.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.ConnectionHeaderOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.ExceptionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.ExceptionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.ExceptionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.RequestHeader - Class in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.RequestHeader.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.RequestHeaderOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.ResponseHeader - Class in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.ResponseHeader.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.ResponseHeaderOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.UserInformation - Class in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.UserInformation.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
RPCProtos.UserInformationOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
rpcs - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
 
RpcServer - Interface in org.apache.hadoop.hbase.ipc
 
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
 
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() - 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.Chore
 
run() - Method in class org.apache.hadoop.hbase.executor.EventHandler
 
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.HBaseClient.Connection
 
run() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Responder
 
run(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
Deprecated.  
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.WALPlayer
 
run() - Method in class org.apache.hadoop.hbase.master.HMaster
Main processing loop for the HMaster.
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.snapshot.SnapshotFileCache.RefreshCacheTask
 
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.HRegionThriftServer
 
run() - Method in class org.apache.hadoop.hbase.regionserver.Leases
 
run() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable
 
run() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
 
run(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
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.replication.regionserver.ReplicationSource
 
run(String[]) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
Execute the export snapshot by copying the snapshot metadata, hfiles and hlogs.
run(String[]) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
 
run() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
 
run() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
 
run(String[]) - Method in class org.apache.hadoop.hbase.tool.Canary
 
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.HBaseFsck
 
run(String[]) - Method in class org.apache.hadoop.hbase.util.Merge
 
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.
runCatalogScan() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Ask for a scan of the catalog table
runCatalogScan(RpcController, MasterAdminProtos.CatalogScanRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
runCatalogScan(RpcController, MasterAdminProtos.CatalogScanRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
runCatalogScan(RpcController, MasterAdminProtos.CatalogScanRequest, RpcCallback<MasterAdminProtos.CatalogScanResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
runCatalogScan(RpcController, MasterAdminProtos.CatalogScanRequest, RpcCallback<MasterAdminProtos.CatalogScanResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
runCatalogScan(RpcController, MasterAdminProtos.CatalogScanRequest, RpcCallback<MasterAdminProtos.CatalogScanResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
running - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
running - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 

S

S - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'S'
SampleUploader - Class in org.apache.hadoop.hbase.mapreduce
Sample Uploader MapReduce
SampleUploader() - Constructor for class org.apache.hadoop.hbase.mapreduce.SampleUploader
 
SASL_DEFAULT_REALM - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
 
SASL_PROPS - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
 
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
 
saslQop - Variable in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.QualityOfProtection
 
SaslStatus - Enum in org.apache.hadoop.hbase.security
 
SaslUtil - Class in org.apache.hadoop.hbase.security
 
SaslUtil() - Constructor for class org.apache.hadoop.hbase.security.SaslUtil
 
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 - 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
 
Scan(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
Create a Scan operation starting at the specified row.
Scan(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
Create a Scan operation for the range of rows specified.
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 - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Base-64 encoded scanner.
scan(RpcController, ClientProtos.ScanRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface
 
scan(RpcController, ClientProtos.ScanRequest, RpcCallback<ClientProtos.ScanResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Interface
 
scan(RpcController, ClientProtos.ScanRequest, RpcCallback<ClientProtos.ScanResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
 
scan(RpcController, ClientProtos.ScanRequest, RpcCallback<ClientProtos.ScanResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Stub
 
scan(RpcController, ClientProtos.ScanRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Scan data in a table.
scan - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
scan - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
the scan object to get a Scanner for
SCAN_ATTRIBUTES_METRICS_DATA - Static variable in class org.apache.hadoop.hbase.client.Scan
 
SCAN_ATTRIBUTES_METRICS_ENABLE - Static variable in class org.apache.hadoop.hbase.client.Scan
 
SCAN_ATTRIBUTES_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.client.Scan
 
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_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 to scan.
SCAN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
SCAN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
SCAN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
SCAN_MAXVERSIONS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
The maximum number of version to return.
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_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.
ScanDeleteTracker - Class in org.apache.hadoop.hbase.regionserver
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.ScanDeleteTracker
Constructor for 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(HColumnDescriptor, long, long, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanInfo
 
ScanInfo(byte[], int, int, long, boolean, long, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanInfo
 
ScanMetrics - Class in org.apache.hadoop.hbase.client.metrics
Provides client-side metrics related to scan operations The data can be passed to mapreduce framework or other systems.
ScanMetrics() - Constructor for class org.apache.hadoop.hbase.client.metrics.ScanMetrics
constructor
scannerCaching - Variable in class org.apache.hadoop.hbase.client.HTable
 
ScannerCallable - Class in org.apache.hadoop.hbase.client
Retries scanner operations such as create, next, etc.
ScannerCallable(HConnection, byte[], Scan, ScanMetrics) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallable
 
scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
scannerGetList(int, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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.
SCANNERID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
SCANNERID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
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
 
ScannerMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
ScannerMessage.Scanner - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
ScannerMessage.Scanner.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
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>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
ScannerResultGenerator(String, RowSpec, Filter, int) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
ScannerTimeoutException - Exception in org.apache.hadoop.hbase.client
Thrown when a scanner has timed out.
ScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver
A query matcher that is specifically designed for the scan case.
ScanQueryMatcher(Scan, ScanInfo, NavigableSet<byte[]>, ScanType, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
Construct a QueryMatcher for a scan
ScanQueryMatcher(Scan, ScanInfo, NavigableSet<byte[]>, long, long, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
Construct a QueryMatcher for a scan that drop deletes from a limited range of rows.
ScanQueryMatcher.MatchCode - Enum in org.apache.hadoop.hbase.regionserver
ScanQueryMatcher.match(org.apache.hadoop.hbase.KeyValue) return codes.
SCANRESULT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
SCANS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
Job parameter that specifies the scan list.
ScanType - Enum in org.apache.hadoop.hbase.regionserver
Enum to distinguish general scan types.
ScanWildcardColumnTracker - Class in org.apache.hadoop.hbase.regionserver
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.ScanWildcardColumnTracker
Return maxVersions of every row.
SchemaResource - Class in org.apache.hadoop.hbase.rest
 
SchemaResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.SchemaResource
Constructor
SCOPETYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
second - Variable in class org.apache.hadoop.hbase.util.Pair
 
SECOND_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
SECONDPART_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
secretManager - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
SecureBulkLoadClient - Class in org.apache.hadoop.hbase.client.coprocessor
Client proxy for SecureBulkLoadProtocol used in conjunction with SecureBulkLoadEndpoint
SecureBulkLoadClient(HTable) - 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) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.BlockingInterface
 
secureBulkLoadHFiles(RpcController, SecureBulkLoadProtos.SecureBulkLoadHFilesRequest, RpcCallback<SecureBulkLoadProtos.SecureBulkLoadHFilesResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Interface
 
secureBulkLoadHFiles(RpcController, SecureBulkLoadProtos.SecureBulkLoadHFilesRequest, RpcCallback<SecureBulkLoadProtos.SecureBulkLoadHFilesResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
 
secureBulkLoadHFiles(RpcController, SecureBulkLoadProtos.SecureBulkLoadHFilesRequest, RpcCallback<SecureBulkLoadProtos.SecureBulkLoadHFilesResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Stub
 
secureBulkLoadHFiles(RpcController, SecureBulkLoadProtos.SecureBulkLoadHFilesRequest, RpcCallback<SecureBulkLoadProtos.SecureBulkLoadHFilesResponse>) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
 
SecureBulkLoadProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.CleanupBulkLoadRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.CleanupBulkLoadRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.CleanupBulkLoadResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.CleanupBulkLoadResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.DelegationTokenProto - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.DelegationTokenProto.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.DelegationTokenProtoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.PrepareBulkLoadRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.PrepareBulkLoadRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.PrepareBulkLoadResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.PrepareBulkLoadResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.SecureBulkLoadHFilesRequest - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.SecureBulkLoadHFilesResponse - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.SecureBulkLoadHFilesResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.SecureBulkLoadService - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.SecureBulkLoadService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
 
SecureBulkLoadProtos.SecureBulkLoadService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.SecureBulkLoadService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadProtos.SecureBulkLoadService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
 
SecureBulkLoadUtil - Class in org.apache.hadoop.hbase.security
 
SecureBulkLoadUtil() - Constructor for class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
 
seek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Seeks all scanners at or below the specified seek key.
seek(KeyValue) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Seek the scanner at or after the specified KeyValue.
seek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
Set the scanner at the seek key.
seek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
seek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
seek(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Reader
 
seek(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
seek() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
Advance the reader to the current position
seek(KeyValue) - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
seekAtOrAfter(HFileScanner, KeyValue) - 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(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Consider the key stream of all the keys in the file, k[0] ..
seekBefore(byte[], int, int) - 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.KeyValue)

Look for the key, but only look after the current position.

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.
seekTo(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
seekTo(byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
An internal API function.
seekTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
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
SeekTo or just before the passed key.
seekTo(byte[], int, int) - 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(byte[], int, int, HFileBlock, boolean, boolean, boolean) - 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(byte[], int, int, 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.
seekToOrBeforeUsingPositionAtOrAfter(byte[], int, int, 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
 
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.DefaultCompactionPolicy
 
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.
selectToken(Text, Collection<Token<? extends TokenIdentifier>>) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
 
send_checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.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_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_exists(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_get(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
 
send_getMultiple(ByteBuffer, List<TGet>) - 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_increment(ByteBuffer, TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.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
 
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
 
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) - 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) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
This acts as the ack for a completed snapshot
sendPing() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
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) - 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<Pair<HRegionInfo, Integer>>) - 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) - Method in class org.apache.hadoop.hbase.master.ServerManager
Sends an MERGE REGIONS RPC to the specified server to merge the specified regions.
sendResponseIfReady() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
If we have a response, and delay is not set, then respond immediately.
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(int) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
sentBytes(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
separator() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
 
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.
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
SequenceFileLogReader - Class in org.apache.hadoop.hbase.regionserver.wal
 
SequenceFileLogReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
Default constructor.
SequenceFileLogReader(Class<? extends HLogKey>) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
This constructor allows a specific HLogKey implementation to override that which would otherwise be chosen via configuration property.
SequenceFileLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
Implementation of HLog.Writer that delegates to SequenceFile.Writer.
SequenceFileLogWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
Default constructor.
SequenceFileLogWriter(Class<? extends HLogKey>) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
This constructor allows a specific HLogKey implementation to override that which would otherwise be chosen via configuration property.
sequenceID - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
sequenceIdChecker - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
 
sequenceNumber - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
SEQUENCENUMBER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
serialize(String, Throwable) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
Converts a ForeignException to an array of bytes.
serialize(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
Serializes its data into destination.
serialize(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
serialize(KeyValue) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
 
SERIALIZEDCOMPARATOR_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
SERIALIZEDFILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
serializeExtraInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
serve() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
 
server - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
server - Variable in class org.apache.hadoop.hbase.executor.EventHandler
 
SERVER - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
server - Variable in class org.apache.hadoop.hbase.master.AssignmentManager
 
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
SERVER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
SERVER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
SERVER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
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
ServerCallable<T> - Class in org.apache.hadoop.hbase.client
Abstract class that implements Callable.
ServerCallable(HConnection, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.ServerCallable
 
ServerCallable(HConnection, byte[], byte[], int) - Constructor for class org.apache.hadoop.hbase.client.ServerCallable
 
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
 
SERVERCURRENTTIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
SERVERINFO_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
ServerLoad - Class in org.apache.hadoop.hbase
This class is used for exporting current state of load on a RegionServer.
ServerLoad(HBaseProtos.ServerLoad) - Constructor for class org.apache.hadoop.hbase.ServerLoad
 
serverLoad - Variable in class org.apache.hadoop.hbase.ServerLoad
 
SERVERLOAD_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
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.
ServerMetricsTmpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
 
ServerMetricsTmpl(TemplateManager) - 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.master.handler.ServerShutdownHandler
 
ServerName - Class in org.apache.hadoop.hbase
Instance of an HBase ServerName.
ServerName(String, int, long) - Constructor for class org.apache.hadoop.hbase.ServerName
 
ServerName(String) - Constructor for class org.apache.hadoop.hbase.ServerName
 
ServerName(String, long) - Constructor for class org.apache.hadoop.hbase.ServerName
 
SERVERNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
SERVERNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
SERVERNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
SERVERNAME_PATTERN - Static variable in class org.apache.hadoop.hbase.ServerName
 
SERVERNAME_SEPARATOR - Static variable in class org.apache.hadoop.hbase.ServerName
This character is used as separator between server hostname, port and startcode.
ServerNotRunningYetException - Exception in org.apache.hadoop.hbase.exceptions
 
ServerNotRunningYetException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ServerNotRunningYetException
 
serverOffline(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
A server is offline, all regions on it are dead.
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
 
ServerShutdownHandler - Class in org.apache.hadoop.hbase.master.handler
Process server shutdown.
ServerShutdownHandler(Server, MasterServices, DeadServer, ServerName, boolean) - Constructor for class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
 
SERVERSTARTCODE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
SERVERVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
 
service - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
SERVICE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
SERVICE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
SERVICENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
services - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
services - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
 
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(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
set(User, InetAddress, Class<? extends IpcProtocol>) - Static method in class org.apache.hadoop.hbase.ipc.RequestContext
Initializes the client credentials for the current request.
set(byte[]) - Method in class org.apache.hadoop.hbase.util.ByteRange
 
set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.ByteRange
 
setAction(int, AccessControlProtos.Permission.Action) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
setAction(int, ClientProtos.MultiAction) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
setAction(int, ClientProtos.MultiAction.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
setAdmin(HBaseAdmin) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
setAgeOfLastAppliedOp(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
Set the age of the last applied operation
setAgeOfLastShippedOp(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Set the age of the last edit that was shipped
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
 
setAmount(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
setAmountIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
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
 
setAssignSeqNum(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
setAssignSeqNum(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
setAssociatedCellCount(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
setAssociatedCellCount(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
setAtomic(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
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.OperationWithAttributes
 
setAttribute(int, HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
setAttribute(int, HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
setAttribute(int, HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
setAttribute(int, HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
setAttribute(int, HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
setAttribute(int, HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
setAttributes(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
setAttributes(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
setAttributes(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
setAttributes(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
setAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
setAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
setAttrs(int, TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
setAttrs(int, TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
setAuthMethod(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
See HTable.setAutoFlush(boolean, boolean)
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
See HTableInterface.setAutoFlush(boolean, boolean)
setAutoFlush(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
Turns 'auto-flush' on or off.
setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
setAutoFlush(boolean, boolean) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
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
 
setAveragePrefixLength(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
setAverageQualifierLength(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
setAverageSuffixLength(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
setBackupMasters(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setBackupMasters(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setBalancerOn(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setBalancerOn(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
setBalancerOn(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.LoadBalancerTracker
Set the balancer on/off
setBalancerRan(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse.Builder
 
setBalancerRunning(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Turn the load balancer on or off.
setBalancerRunning(RpcController, MasterAdminProtos.SetBalancerRunningRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
setBalancerRunning(RpcController, MasterAdminProtos.SetBalancerRunningRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
setBalancerRunning(RpcController, MasterAdminProtos.SetBalancerRunningRequest, RpcCallback<MasterAdminProtos.SetBalancerRunningResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
setBalancerRunning(RpcController, MasterAdminProtos.SetBalancerRunningRequest, RpcCallback<MasterAdminProtos.SetBalancerRunningResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
setBalancerRunning(RpcController, MasterAdminProtos.SetBalancerRunningRequest, RpcCallback<MasterAdminProtos.SetBalancerRunningResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
setBaseTimestampDivide(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
setBatch(int) - Method in class org.apache.hadoop.hbase.client.Scan
Set the maximum number of values 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
 
setBatchSize(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
setBigdecimalMsg(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
setBitwiseOp(ComparatorProtos.BitComparator.BitwiseOp) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setBlocks(int) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
 
setBlocksize(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setBody(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
 
setBoolean(String, boolean) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
setBooleanIfUnset(String, boolean) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
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
 
setBulkToken(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
setBulkToken(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
setBulkToken(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
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.protobuf.generated.ClientProtos.Get.Builder
 
setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
setCacheBloomsOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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
 
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
 
setCaching(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setCachingIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setCall(ClientProtos.CoprocessorServiceCall) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
setCall(ClientProtos.CoprocessorServiceCall.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
setCallId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
setCallId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
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
 
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(int, HBaseProtos.Cell) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
setCell(int, HBaseProtos.Cell.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
setCellBlockCodecClass(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
setCellBlockCompressorClass(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
setCellBlockMeta(RPCProtos.CellBlockMeta) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
setCellBlockMeta(RPCProtos.CellBlockMeta.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
setCellBlockMeta(RPCProtos.CellBlockMeta) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
setCellBlockMeta(RPCProtos.CellBlockMeta.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
setCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
setCellType(HBaseProtos.CellType) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
setChance(float) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
Set the chance that a row is included.
setChance(float) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
setChanceForSameQualifier(float) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
setChanceForSimilarQualifier(float) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
setChanceForZeroValue(float) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
setCharset(Charset) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
Specifies the Charset to use to convert the row key to a String.
setCharset(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
setCheckHdfs(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setClass(String, Class<?>, Class<?>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
setClassLoader(ClassLoader) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
setClassName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
setClose() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Call this when the next invocation of call should close the scanner
setClosed(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
setCloseScanner(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
setClosestRowBefore(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
setClosestRowBefore(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
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(UUID) - Method in class org.apache.hadoop.hbase.client.Mutation
Set the replication custer id.
setClusterId(AdminProtos.UUID) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
setClusterId(AdminProtos.UUID.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
setClusterId(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
setClusterId(ClusterIdProtos.ClusterId) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setClusterId(ClusterIdProtos.ClusterId.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setClusterId(UUID) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Set the cluster id of this key
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
 
setClusterkey(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
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(ClusterStatusProtos.ClusterStatus) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
setClusterStatus(ClusterStatusProtos.ClusterStatus.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse.Builder
 
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
 
setColumn(int, ClientProtos.Column) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
setColumn(int, ClientProtos.Column.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
setColumn(int, ClientProtos.Column) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
setColumn(int, ClientProtos.Column.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
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
 
setColumnFamilies(int, HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
setColumnFamilies(int, HBaseProtos.ColumnFamilySchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
setColumnFamilies(HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
setColumnFamilies(HBaseProtos.ColumnFamilySchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
setColumnFamilies(HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
setColumnFamilies(HBaseProtos.ColumnFamilySchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
setColumnFamily(String) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
 
setColumnFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
setColumnFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
setColumnFamilyLength(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
setColumnName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
setColumnQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
setColumnQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
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
 
setColumns(int, ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
setColumns(int, ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
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.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
 
setColumnValue(int, ClientProtos.MutationProto.ColumnValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
setColumnValue(int, ClientProtos.MutationProto.ColumnValue.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
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
 
setCommonPrefix(byte[]) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
get/set
setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Compression types supported in hbase.
setCompactionState(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
setCompactionState(AdminProtos.GetRegionInfoResponse.CompactionState) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
setComparable(ComparatorProtos.ByteArrayComparable) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
setComparable(ComparatorProtos.ByteArrayComparable.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
setComparable(ComparatorProtos.ByteArrayComparable) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
setComparable(ComparatorProtos.ByteArrayComparable.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
setComparable(ComparatorProtos.ByteArrayComparable) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
setComparable(ComparatorProtos.ByteArrayComparable.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
setComparator(ComparatorProtos.Comparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
setComparator(ComparatorProtos.Comparator.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
setComparator(ComparatorProtos.Comparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
setComparator(ComparatorProtos.Comparator.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
setComparator(ComparatorProtos.Comparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
setComparator(ComparatorProtos.Comparator.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
setComparatorClass(Class<? extends RawComparator>) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setComparatorClassName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
setCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
setCompareFilter(FilterProtos.CompareFilter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
setCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
setCompareFilter(FilterProtos.CompareFilter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
setCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
setCompareFilter(FilterProtos.CompareFilter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
setCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
setCompareFilter(FilterProtos.CompareFilter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
setCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
setCompareFilter(FilterProtos.CompareFilter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
setCompareOp(HBaseProtos.CompareType) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
setCompareOp(HBaseProtos.CompareType) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
setCompareType(HBaseProtos.CompareType) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
setCompleteSequenceId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
setCompression(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
setCompressionCodec(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setCompressionCodec(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog.Entry
Set compression context for this entry.
setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
 
setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Compression types supported in hbase.
setCondition(ClientProtos.Condition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
setCondition(ClientProtos.Condition.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
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.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.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.master.snapshot.SnapshotLogCleaner
This method should only be called once, as it starts a thread to keep the cache up-to-date.
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.replication.master.ReplicationLogCleaner
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.tool.Canary
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.trace.HBaseLocalFileSpanReceiver
 
setConf(Configuration) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
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(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
setConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
setConfiguration(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
setConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
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.
setContentLength(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
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
 
setCoprocessors(int, HBaseProtos.Coprocessor) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
setCoprocessors(int, HBaseProtos.Coprocessor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
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
 
setCount(int) - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
Set the current count to a new count
setCounter(String, long) - Method in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
 
setCreateTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
setCreationTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
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.
setCurrentCompactedKVs(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
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
 
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
 
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.
setDataIndexCount(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setDataIndexCount(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
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
 
setDeadServers(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setDeadServers(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
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
 
setDeclaringClass(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
setDefaultClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
setDeferredLogFlush(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
This is used to defer the log edits syncing to the file system.
setDeletedTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
Deletes the table in zookeeper.
setDeleteFamilyBloomFilterFaulty() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
setDeletes(List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
list of TDeletes to delete
setDeleteSingle(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
the TDelete to execute if the check succeeds
setDeleteSingle(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
the TDelete to delete
setDeleteSingleIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
setDeleteSingleIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
setDeletesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
setDeleteType(BulkDeleteProtos.BulkDeleteRequest.DeleteType) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
setDeleteType(ClientProtos.MutationProto.DeleteType) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
setDeleteType(TDeleteType) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setDeleteTypeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
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.
setDestinationServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
setDestinationServer(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
setDestServerName(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
setDestServerName(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
setDisabledTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
Sets the specified table as DISABLED in zookeeper.
setDisablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
Sets the specified table as DISABLING in zookeeper.
setDisplayFullReport() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Display the full report from fsck.
setDone(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse.Builder
 
setDone(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
setDoNotRetry(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
setDropDependentColumn(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
setEdit(AdminProtos.WALEntry.WALEdit) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
setEdit(AdminProtos.WALEntry.WALEdit.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
setEffectiveUser(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
setEnable(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest.Builder
 
setEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
 
setEnabledTable(String) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
setEnabledTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
Sets the ENABLED state in the cache and creates or force updates a node to ENABLED state for the specified table
setEnablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
Sets the specified table as ENABLING in zookeeper.
setEncodedRegionName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
setEncodeOnDisk(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Set the flag indicating that we only want to encode data block in cache but not on disk.
setEndKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
setEndKey(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
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
 
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
 
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
 
setEndTime(long) - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
setEntry(int, AdminProtos.WALEntry) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
setEntry(int, AdminProtos.WALEntry.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
setEntryCount(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setEntryCount(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
setErr(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
 
setErrorHandler(HBaseRPCErrorHandler) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Set the handler for calling out of RPC for error conditions.
setErrorHandler(HBaseRPCErrorHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
 
setErrorInfo(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
setErrorMessage(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
setEventTypeCode(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setEvictOnClose(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Only used for testing.
setException(IOException) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Call
Set the exception when there is an error.
setException(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
setException(HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
setException(RPCProtos.ExceptionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
setException(RPCProtos.ExceptionResponse.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
setExceptionClassName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
setExistenceOnly(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
setExistenceOnly(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
setExists(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
setExists(int, boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
setExpectedTimeout(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse.Builder
 
setExpiration(long) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
 
setExpirationDate(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
setExpirationDate(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
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.
setFakeLookupMode(boolean) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
 
setFamily(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
setFamily(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
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.checkAndPut_args
column family to check
setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setFamily(byte[]) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
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.checkAndPut_args
 
setFamilyMap(NavigableMap<byte[], List<? extends Cell>>) - Method in class org.apache.hadoop.hbase.client.Mutation
Method for setting the put's familyMap
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
 
setFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
setFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
setFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
setFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
setFamilyScope(int, AdminProtos.WALEntry.WALEdit.FamilyScope) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
setFamilyScope(int, AdminProtos.WALEntry.WALEdit.FamilyScope.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
setFanIndex(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
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.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.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.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.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.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.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(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(TScan._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
setFieldValue(TTimeRange._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
setFileInfoOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setFileInfoOffset(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
setFileName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Get
Apply the specified server-side filter when performing the Get.
setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Scan
Apply the specified server-side filter when performing the Scan.
setFilter(HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
setFilter(HBaseProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
setFilter(HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
setFilter(HBaseProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
setFilter(HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
setFilter(HBaseProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
setFilter(HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
setFilter(HBaseProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
setFilter(HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
setFilter(HBaseProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
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
 
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
 
setFilterIfMissing(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Set whether entire row should be filtered if column is not found.
setFilterIfMissing(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
setFilters(int, HBaseProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
setFilters(int, HBaseProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
setFirst(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.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
 
setFirstDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
setFirstInsertionIndex(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setFirstPart(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
setFirstRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
 
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(String) - 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
 
setFixMeta(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFixReferenceFiles(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFixSplitParents(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFixTableOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFixVersionFile(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setFloat(String, float) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
setFlushed(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
setForce(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
setForcible(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
setForcible(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
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
 
setFrom(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
setFsDefault(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
setFsToken(SecureBulkLoadProtos.DelegationTokenProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
setFsToken(SecureBulkLoadProtos.DelegationTokenProto.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
setFuzzyKeysData(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
setFuzzyKeysData(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
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.
setGeneralBloomFilterFaulty() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
setGenericException(ErrorHandlingProtos.GenericExceptionMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
setGenericException(ErrorHandlingProtos.GenericExceptionMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
setGet(ClientProtos.Get) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
setGet(ClientProtos.Get.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
setGet(ClientProtos.Get) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
setGet(ClientProtos.Get.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
setGet(int, ClientProtos.Get) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
setGet(int, ClientProtos.Get.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
setGet(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
the TGet to check for
setGet(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
the TGet to fetch
setGetIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
setGetIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
setGets(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
setGetsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
setGroupPermissions(String, byte[], 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.
setHbaseVersion(FSProtos.HBaseVersionFileContent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setHbaseVersion(FSProtos.HBaseVersionFileContent.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
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
 
setHeapSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
 
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
 
setHFileCorruptionChecker(HFileCorruptionChecker) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setHostName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
setHostname(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated. Allows subclasses to set the HTable.
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to set the HTable.
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Sets the HBase table.
setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Sets the HBase table.
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.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.OperationWithAttributes
This method allows you to set an identifier on an operation.
setId(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
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
 
setIdentifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
setIdentifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
setIfOlderThanTs(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
setIfUnset(String, String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
setIgnorePreCheckPermission(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setIncludesMvccVersion(byte) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setIncludesMvccVersion(boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setIncrement(TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
the TIncrement to increment
setIncrementIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
setInfoFamilyCachingForMeta(boolean) - Static method in class org.apache.hadoop.hbase.master.MasterFileSystem
Enable in memory caching for .META.
setInfoServerPort(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
setInMemory(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
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
 
setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated.  
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
 
setInt(String, int) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
setInterpreterClassName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
setInterpreterSpecificBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
setIntHeader(String, int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
 
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.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.get_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.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.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.thrift2.generated.THBaseService.checkAndDelete_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.get_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.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.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
 
setIsMajor(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
setIsMasterRunning(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Scan
 
setIsShared(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
setIssueDate(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
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
 
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
 
setKeepDeletedCells(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setKey(AdminProtos.WALEntry.WALKey) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
setKey(AdminProtos.WALEntry.WALKey.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
setKey(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
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
 
setKeyId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
setKeyType(HBaseProtos.CellType) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
setKeyValueBytes(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.Builder
 
setKind(AuthenticationProtos.TokenIdentifier.Kind) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
setKind(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
setLastContact(long) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
 
setLastDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setLastDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
setLastFlushedSequenceId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
setLastFlushTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
setLastRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
 
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(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Set whether only the latest version of the column value should be compared.
setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
setLeastSigBits(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
setLenAsVal(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
setLength(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
setLength(int) - Method in class org.apache.hadoop.hbase.util.ByteRange
 
setLimit(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
setLimit(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
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
 
setLineNumber(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
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
 
setLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
setLiveServers(int, ClusterStatusProtos.LiveServerInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setLiveServers(int, ClusterStatusProtos.LiveServerInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setLoad(HBaseProtos.ServerLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
setLoad(HBaseProtos.ServerLoad.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
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.protobuf.generated.ClientProtos.Scan.Builder
 
setLoaded(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
setLoaded(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
setLoadOnOpenDataOffset(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
setLoadOnOpenOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
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
 
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.
setLockOwner(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
setLockOwner(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
setLockOwner(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
setLogSequenceNumber(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
setLong(String, long) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
setLongMsg(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
setMajor(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
setMapEntries(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
setMapEntries(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
setMapEntry(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
setMapEntry(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
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(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setMaster(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setMaster(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
setMaster(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
setMaster(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterListTmpl.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) - 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.
setMasterCoprocessors(int, HBaseProtos.Coprocessor) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setMasterCoprocessors(int, HBaseProtos.Coprocessor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
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.
setMaxChunkSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
 
setMaxColumn(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
setMaxColumnInclusive(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
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.
setMaxHeapMB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
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
 
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
 
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.
setMaxResultSize(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
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.LruBlockCache
 
setMaxStamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
setMaxStampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
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.client.UnmodifyableHColumnDescriptor
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
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
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
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.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.
setMemstoreSizeMB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
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
 
setMemstoreTS(long) - Method in class org.apache.hadoop.hbase.KeyValue
Deprecated. 
setMessage(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
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.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
 
setMetaIndexCount(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
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) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
Sets the location of .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 .META.
setMethodName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
setMethodName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
setMethodName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
setMetrics(int, HBaseProtos.NameInt64Pair) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
setMetrics(int, HBaseProtos.NameInt64Pair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
setMinColumn(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
setMinColumnInclusive(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
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
 
setMinTimestamp(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setMinVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setMoreResults(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
setMostSigBits(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID.Builder
 
setMutateType(ClientProtos.MutationProto.MutationType) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
setMutation(ClientProtos.MutationProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
setMutation(ClientProtos.MutationProto.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction.Builder
 
setMutation(ClientProtos.MutationProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
setMutation(ClientProtos.MutationProto.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
setMutationRequest(int, ClientProtos.MutationProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
setMutationRequest(int, ClientProtos.MutationProto.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest.Builder
 
setMvccVersion(long) - Method in class org.apache.hadoop.hbase.KeyValue
 
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
Set the name of the table.
setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
setName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
setName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
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
 
setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
setName(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
setName(int, String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
setName(String) - Method in class org.apache.hadoop.hbase.util.HasThread
 
setNegativeIndex(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setNextCallSeq(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
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.
setNodeFirstInsertionIndexes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
write
setNumberOfRequests(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
setNumberOfRowPrefixes(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
setNumberOfRows(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
setNumberOfRows(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
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
 
setNumDataIndexLevels(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
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
Deprecated. 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
 
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
Deprecated. 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.
setNumRowBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
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.getScannerRows_args
 
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
 
setNumValueBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
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.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
setOffPeak(boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
setOffset(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
setOn(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
setOnlineRegions(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
 
setOpenInfo(int, AdminProtos.OpenRegionRequest.RegionOpenInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
setOpenInfo(int, AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
setOpeningState(int, AdminProtos.OpenRegionResponse.RegionOpeningState) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
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.HTable
 
setOperator(FilterProtos.FilterList.Operator) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
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
 
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. 
setOwnerString(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated. 
setPageSize(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
setParent(TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setParentId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
setParentStartPosition(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
get/set
setPassword(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
setPassword(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
setPath(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
setPattern(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
setPatternFlags(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
setPayload(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
setPermission(int, AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
setPermission(int, AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
setPermission(AccessControlProtos.UserPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
setPermission(AccessControlProtos.UserPermission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
setPermission(AccessControlProtos.UserPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
setPermission(AccessControlProtos.UserPermission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
setPermission(AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
setPermission(AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
setPermission(int, AccessControlProtos.UserPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
setPermission(int, AccessControlProtos.UserPermission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse.Builder
 
setPermissions(int, AccessControlProtos.UserTablePermissions.UserPermissions) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
setPermissions(int, AccessControlProtos.UserTablePermissions.UserPermissions.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.Builder
 
setPermissions(int, AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
setPermissions(int, AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
setPingInterval(Configuration, int) - Static method in class org.apache.hadoop.hbase.ipc.HBaseClient
set the ping interval value in configuration
setPort(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
setPort(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
setPort(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
setPosition(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
setPosition(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
 
setPrefix(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
setPrefix(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
setPrefixLengthVariance(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
setPrevBalanceValue(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse.Builder
 
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.
setPrevValue(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse.Builder
 
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
 
setProcessed(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
setProtocol(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
setPurpose(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
setPut(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
the TPut to put if the check succeeds
setPut(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
the TPut to put
setPutIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
setPutIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
setPuts(List<TPut>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
a list of TPuts to commit
setPutsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
setQosFunction(Function<Pair<RPCProtos.RequestHeader, Message>, Integer>) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Gets the QOS level for this call.
setQosFunction(Function<Pair<RPCProtos.RequestHeader, Message>, Integer>) - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
 
setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
setQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
setQualifier(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
setQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
setQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
setQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
setQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
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.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.checkAndPut_args
 
setQualifierLengthVariance(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
setQualifierOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setQualifiers(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
setQualifierValue(int, ClientProtos.MutationProto.ColumnValue.QualifierValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
setQualifierValue(int, ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
setRandomizer(Random) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
setRange(FSProtos.Reference.Range) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
setRaw(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
Enable/disable "raw" mode for this scan.
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
 
setReadRequestsCount(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
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
 
setRealUser(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
setReason(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
setRegion(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
setRegion(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest.Builder
 
setRegionA(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
setRegionA(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
setRegionA(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
setRegionA(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
setRegionB(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
setRegionB(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
setRegionB(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
setRegionB(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest.Builder
 
setRegionCachePrefetch(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
Enable or disable region cache prefetch for the table.
setRegionCachePrefetch(byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
Enable or disable region cache prefetch for the table.
setRegionCachePrefetch(Configuration, byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
Enable or disable region cache prefetch for the table.
setRegionFilter(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
sets the region by which output will be filtered
setRegionId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
setRegionInfo(int, HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
setRegionInfo(int, HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
setRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
setRegionInfo(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
setRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
setRegionInfo(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
setRegionLoads(int, HBaseProtos.RegionLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
setRegionLoads(int, HBaseProtos.RegionLoad.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
setRegionName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
setRegionName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
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
 
setRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
setRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
setRegions(int, TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
setRegions(int, TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
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.ReplicationPeer
Set the list of region servers for that peer
setRegionsInTransition(int, ClusterStatusProtos.RegionInTransition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setRegionsInTransition(int, ClusterStatusProtos.RegionInTransition.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
setRegionSpecifier(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
setRegionSpecifier(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
setRegionState(ClusterStatusProtos.RegionState) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
setRegionState(ClusterStatusProtos.RegionState.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
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
setRegionToFlush(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
setReplicating(boolean) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Kill switch for all replication-related features
setReplication(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Set the new replication state for this cluster
setReportEndTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
setReportStartTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
setRequest(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
setRequestParam(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
setRequests(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
 
setRequests(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
setRequests(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
setRequests(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
setResponse(Message, CellScanner) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Call
Set the return value when there is no error.
setResponse(Object, CellScanner, Throwable, String) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
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
 
setResult(R) - Method in class org.apache.hadoop.hbase.client.Action
 
setResult(ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
setResult(ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
setResult(int, ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
setResult(int, ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse.Builder
 
setResult(int, ClientProtos.ActionResult) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
setResult(int, ClientProtos.ActionResult.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
setResult(ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
setResult(ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
setResult(int, ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
setResult(int, ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
setResultSizeBytes(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
setRetCode(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Append
 
setRIT(int) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
Set the number of regions in transition.
setRIT(int) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
 
setRITCountOverThreshold(int) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
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.MetricsMasterSourceImpl
 
setRITOldestAge(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
Set the oldest region in transition.
setRITOldestAge(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
 
setRootDir(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
setRootIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
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
 
setRootRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Used to denote if the current table represents -ROOT- region.
setRow(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
setRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
setRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
setRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
setRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
setRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
setRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
setRow(byte[], int, short) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
Set current row
setRow(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
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.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.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
 
setRowBatchSize(int) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated. 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.regionserver.wal.HLogPrettyPrinter
sets the region by which output will be filtered
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.checkAndPut_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
 
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.
setRowProcessorClassName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
setRowProcessorInitializerMessage(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
setRowProcessorInitializerMessageName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest.Builder
 
setRowProcessorResult(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult.Builder
 
setRows(int, CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
setRows(int, CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
setRowsDeleted(long) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
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) - Static method in class org.apache.hadoop.hbase.ipc.HBaseClientRPC
 
setSaslTokenResponse(ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
setScan(ClientProtos.Scan) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
setScan(ClientProtos.Scan.Builder) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
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(ClientProtos.Scan) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
setScan(ClientProtos.Scan.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument.Builder
 
setScan(ClientProtos.Scan) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
setScan(ClientProtos.Scan.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
setScan(TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
the scan object to get a Scanner for
setScanIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
setScannerCaching(int) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated. Use Scan.setCaching(int)
setScannerCaching(JobConf, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated. 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(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
setScannerId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
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
 
setScanQueryMatcher(ScanQueryMatcher) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
setScanResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse.Builder
 
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.regionserver.wal.WALEdit
 
setScopeType(AdminProtos.WALEntry.WALEdit.ScopeType) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope.Builder
 
setSecond(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
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
 
setSecondPart(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
setSecretManager(SecretManager<? extends TokenIdentifier>) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
 
setSequenceFilter(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
sets the region by which output will be filtered
setSequenceID(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
setSequenceNumber(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
setSequenceNumber(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
Called by HRegionServer when it opens a new region to ensure that log sequence numbers are always greater than the latest sequence number of the region being brought on-line.
setSerializedComparator(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
setSerializedFilter(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter.Builder
 
setServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
setServer(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
setServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
setServer(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
setServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
setServer(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
setServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
setServer(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer.Builder
 
setServerCurrentTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
setServerInfo(AdminProtos.ServerInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
setServerInfo(AdminProtos.ServerInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
setServerLoad(HBaseProtos.ServerLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
setServerLoad(HBaseProtos.ServerLoad.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
setServerName(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
setServerName(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
setServerName(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
setServerName(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
setServerName(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
setServerName(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
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, Log) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
Set the number of retries to use serverside when trying to communicate with another server over HConnection.
setServerStartCode(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
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
 
setService(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
setService(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto.Builder
 
setServiceName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
setShowAppendWarning(boolean) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
 
setShowAppendWarning(boolean) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
setSidelineBigOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setSidelineDir(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
setSingleColumnValueFilter(FilterProtos.SingleColumnValueFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
setSingleColumnValueFilter(FilterProtos.SingleColumnValueFilter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
setSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Set the size of the log queue
setSkipChecks(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
 
setSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
setSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
setSnapshot(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest.Builder
 
setSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
setSnapshot(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest.Builder
 
setSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
setSnapshot(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest.Builder
 
setSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
setSnapshot(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse.Builder
 
setSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
setSnapshot(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest.Builder
 
setSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
setSnapshot(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest.Builder
 
setSnapshotHandlerForTesting(TakeSnapshotHandler) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Set the handler for the current snapshot
setSnapshots(int, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
setSnapshots(int, HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse.Builder
 
setSocketSendBufSize(int) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Sets the socket buffer size used for responding to RPCs.
setSocketSendBufSize(int) - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
 
setSocketTimeout(Configuration, int) - Static method in class org.apache.hadoop.hbase.ipc.HBaseClient
Set the socket timeout
setSortedPrefixes(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
setSource(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
setSource(MetricsThriftServerSource) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
setSpec(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
setSpec(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
setSplit(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
 
setSplit(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
setSplitkey(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
setSplitKeys(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
setSplitPoint(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
setStackTrace(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
setStamp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
setStartCode(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
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
 
setStartDate(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
setStartKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
 
setStartKey(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
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
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Set the start row of the scan.
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
setStartRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
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
 
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.thrift2.generated.TScan
 
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
 
setStartTime(long) - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
setState(ClusterStatusProtos.RegionState.State) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
setState(ZooKeeperProtos.ReplicationState.State) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
setState(ZooKeeperProtos.SplitLogTask.State) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
setState(ZooKeeperProtos.Table.State) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
setState(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationStateImpl
 
setState(boolean) - Method in interface org.apache.hadoop.hbase.replication.ReplicationStateInterface
Set the state of replication.
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
Set the stop row.
setStopRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
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.thrift2.generated.TScan
 
setStopRowKey(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
setStoreFile(int, String) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
setStorefileIndexSizeMB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
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
 
setStorefiles(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
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
 
setStorefileSizeMB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
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
 
setStoreLimit(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
setStoreLimit(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
setStoreOffset(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
setStoreOffset(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
setStores(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
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
 
setStoreUncompressedSizeMB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
setStrings(String, String...) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
 
setSubstr(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
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.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(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
 
setSuccess(List<TResult>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_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.thrift2.generated.THBaseService.checkAndDelete_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.get_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.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
 
setSuffixLengthVariance(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
setSynchronous(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest.Builder
 
setTable(String) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
 
setTable(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
setTable(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest.Builder
 
setTable(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
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.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.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.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.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.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
 
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.thrift2.generated.THBaseService.checkAndDelete_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.get_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.increment_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(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest.Builder
 
setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest.Builder
 
setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest.Builder
 
setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest.Builder
 
setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest.Builder
 
setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest.Builder
 
setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest.Builder
 
setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
setTableNames(int, String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest.Builder
 
setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated. 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
 
setTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
setTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest.Builder
 
setTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
setTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest.Builder
 
setTableSchema(int, HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
setTableSchema(int, HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse.Builder
 
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
 
setThird(C) - Method in class org.apache.hadoop.hbase.util.Triple
 
setThreadId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
setThreadReadPoint(long) - Static method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
Set the thread read point to the given value.
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 META during the last few seconds specified by hbase.admin.fsck.timelag
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(HBaseProtos.TimeRange) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
setTimeRange(HBaseProtos.TimeRange.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
setTimeRange(HBaseProtos.TimeRange) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
setTimeRange(HBaseProtos.TimeRange.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
setTimeRange(HBaseProtos.TimeRange) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
setTimeRange(HBaseProtos.TimeRange.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
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
 
setTimeRangeTracker(TimeRangeTracker) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
Set TimeRangeTracker
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
 
setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.master.RegionState
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
setTimestamp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
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
 
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
 
setTimestampDiffSize(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
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.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
 
setTimestamps(int, long) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
setTimeToLive(int) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setTimeToLive(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
setTo(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
setToken(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
setToken(AuthenticationProtos.Token) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
setToken(AuthenticationProtos.Token.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse.Builder
 
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
 
setTotalCompactingKVs(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
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
 
setTotalNumberOfRequests(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
setTotalRegions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
setTotalStaticBloomSizeKB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
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
 
setTotalStaticIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
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
 
setTotalUncompressedBytes(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setTotalUncompressedBytes(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
setTrace(int, ErrorHandlingProtos.StackTraceElementMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
setTrace(int, ErrorHandlingProtos.StackTraceElementMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
setTraceId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo.Builder
 
setTraceInfo(Tracing.RPCTInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
setTraceInfo(Tracing.RPCTInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
setTransitionInZK(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
setTtl(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
setTtl(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
setType(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
setType(HBaseProtos.RegionSpecifier.RegionSpecifierType) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
setType(HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.hadoop.hbase.util.HasThread
 
setUncompressedDataIndexSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
setUncompressedDataIndexSize(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map
 
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).
setupConnection() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
setupIOstreams() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
setupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
setUsedHeapMB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad.Builder
 
setUser(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
setUser(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions.Builder
 
setUserInfo(RPCProtos.UserInformation) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
setUserInfo(RPCProtos.UserInformation.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
setUsername(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
setUsername(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
setUserPermissions(String, byte[], 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.
setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
setValue(String, String) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
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(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Setter for storing metadata as a (key, value) pair in HTableDescriptor.values map
setValue(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
 
setValue(ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
setValue(ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult.Builder
 
setValue(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
setValue(HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
setValue(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
setValue(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
setValue(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell.Builder
 
setValue(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue.Builder
 
setValue(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
setValue(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
setValue(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
setValue(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
setValue(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse.Builder
 
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
 
setValue(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
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.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
 
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.checkAndPut_args
 
setValueLength(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
 
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
 
setValues(int, CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
setVersion(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
setVersion(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
setVersion(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
setVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
 
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
setVersionOfClosingNode(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
setVersionOfOfflineNode(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
setVersionsDeleted(long) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
setVictimCache(BucketCache) - 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.
setWatchIfNodeExists(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Watch the specified znode, but only if exists.
setWebuiPort(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
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
Sets the size of the buffer in bytes.
setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
setWriteRequestsCount(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad.Builder
 
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
 
setWriteTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey.Builder
 
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
Set whether this Delete should be written to the WAL or not.
setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
setWriteToWal(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setWriteToWal(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setWriteToWal(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setWriteToWalIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
setWriteToWalIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
setWriteToWalIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
setYetToUpdateRegions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse.Builder
 
SEVENTY_FIFTH_PERCENTILE_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
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.
shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.ByteRange
Create a new ByteRange that points at this range's byte[].
shipBatch(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(boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
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
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
 
shouldCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
shouldCacheCompressed() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
shouldCacheDataOnRead() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Returns whether the blocks of this HFile should be cached on read or not.
shouldCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
shouldCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
shouldCloseConnection - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
shouldComplete() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
For use by the coprocessor framework.
shouldEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
 
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
 
shouldRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
 
shouldSeek(Scan, long) - Method in class org.apache.hadoop.hbase.regionserver.MemStore
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.ConstantSizeRegionSplitPolicy
 
shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
 
shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
 
shouldSplitHlog - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
 
shouldUseScanner(Scan, SortedSet<byte[]>, 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, SortedSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
 
shouldUseScanner(Scan, SortedSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
 
shouldUseScanner(Scan, SortedSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
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
 
showAppendWarning - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
 
shutdown() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Shuts down the HBase cluster
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.DoubleBlockCache
 
shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
Sends a shutdown to all SingleSizeCache's contained by this cache.
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, MasterAdminProtos.ShutdownRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
shutdown() - Method in class org.apache.hadoop.hbase.metrics.HBaseInfo.HBaseInfoMBean
Deprecated.  
shutdown(RpcController, MasterAdminProtos.ShutdownRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
shutdown(RpcController, MasterAdminProtos.ShutdownRequest, RpcCallback<MasterAdminProtos.ShutdownResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
shutdown(RpcController, MasterAdminProtos.ShutdownRequest, RpcCallback<MasterAdminProtos.ShutdownResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
shutdown(RpcController, MasterAdminProtos.ShutdownRequest, RpcCallback<MasterAdminProtos.ShutdownResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
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(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.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
 
SimpleBlockCache - Class in org.apache.hadoop.hbase.io.hfile
Simple one RFile soft reference cache.
SimpleBlockCache() - Constructor for class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
Constructor
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.
SINGLECOLUMNVALUEFILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
SingleSizeCache - Class in org.apache.hadoop.hbase.io.hfile.slab
SingleSizeCache is a slab allocated cache that caches elements up to a single size.
SingleSizeCache(int, int, SlabItemActionWatcher) - Constructor for class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
Default constructor.
SINK_AGE_OF_LAST_APPLIED_OP - Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
 
SINK_APPLIED_BATCHES - Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
 
SINK_APPLIED_OPS - Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
 
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.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
Returns the total size of the block cache, in bytes.
size() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
size() - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
 
size() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Get the size of this cache (number of cached blocks)
size() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
 
size() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
 
size() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
 
size - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
size() - Method in class org.apache.hadoop.hbase.master.DeadServer
 
size() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Gets the size (number of entries) of the map.
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.util.byterange.ByteRangeSet
 
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.SoftValueSortedMap
 
size() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
sizeIndexOfAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
 
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
 
skip(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Increment position in buffer.
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_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 KeyValue 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
 
skipSleepCycle() - Method in class org.apache.hadoop.hbase.util.Sleeper
If currently asleep, stops sleeping; if not asleep, will skip the next sleep cycle.
SlabCache - Class in org.apache.hadoop.hbase.io.hfile.slab
SlabCache is composed of multiple SingleSizeCaches.
SlabCache(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
Default constructor, creates an empty SlabCache.
sleep() - Method in class org.apache.hadoop.hbase.Chore
Sleep for period.
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
 
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.ReplicationSource
Do the sleeping logic
sleepUntilNextRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
Sleep for a exponentially back off time
sleepWithoutInterrupt(long) - Static method in class org.apache.hadoop.hbase.util.Threads
Sleeps for the given amount of time even if interrupted.
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_MUTATE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
SLOW_MUTATE_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
 
snapshot(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Take a snapshot for the given table.
snapshot(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create a timestamp consistent snapshot for the given table.
snapshot(String, String, HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Create typed snapshot of the table.
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, MasterAdminProtos.TakeSnapshotRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
Triggers an asynchronous attempt to take a snapshot.
snapshot - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
snapshot(RpcController, MasterAdminProtos.TakeSnapshotRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
snapshot(RpcController, MasterAdminProtos.TakeSnapshotRequest, RpcCallback<MasterAdminProtos.TakeSnapshotResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
snapshot(RpcController, MasterAdminProtos.TakeSnapshotRequest, RpcCallback<MasterAdminProtos.TakeSnapshotResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
snapshot(RpcController, MasterAdminProtos.TakeSnapshotRequest, RpcCallback<MasterAdminProtos.TakeSnapshotResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
snapshot - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotTask
 
SNAPSHOT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Name of the directory to store all snapshots.
SNAPSHOT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
SNAPSHOT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
SNAPSHOT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
SNAPSHOT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
SNAPSHOT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
SNAPSHOT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
snapshot_jsp - Class in org.apache.hadoop.hbase.generated.master
 
snapshot_jsp() - Constructor for class org.apache.hadoop.hbase.generated.master.snapshot_jsp
 
SNAPSHOT_LAYOUT_VERSION - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Version of the fs layout for a snapshot.
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_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
Keep threads alive in request pool for max of 60 seconds
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_TMP_DIR_NAME - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Temporary directory under the snapshot directory to store in-progress snapshots
SnapshotCreationException - Exception in org.apache.hadoop.hbase.exceptions
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.exceptions.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.exceptions.SnapshotCreationException
Failure to create the specified snapshot
SnapshotCreationException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.exceptions.SnapshotCreationException
Failure to create the specified snapshot due to an external cause
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
 
SnapshotDoesNotExistException - Exception in org.apache.hadoop.hbase.exceptions
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.exceptions.SnapshotDoesNotExistException
 
SnapshotDoesNotExistException(HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.exceptions.SnapshotDoesNotExistException
 
SnapshotExistsException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when a snapshot exists but should not
SnapshotExistsException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.exceptions.SnapshotExistsException
Failure due to the snapshot already existing
snapshotFailure(String, Exception) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTask
 
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
Tool for dumping snapshot information.
SnapshotInfo() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotInfo
 
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.
SnapshotLogCleaner - Class in org.apache.hadoop.hbase.master.snapshot
Implementation of a log cleaner that checks if a log is still used by snapshots of HBase tables.
SnapshotLogCleaner() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
 
SnapshotManager - Class in org.apache.hadoop.hbase.master.snapshot
This class manages the procedure of taking and restoring snapshots.
SnapshotManager(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Construct a snapshot manager.
SnapshotManager(MasterServices, ProcedureCoordinator, ExecutorService) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Fully specify all necessary components of a snapshot manager.
SnapshotReferenceUtil - Class in org.apache.hadoop.hbase.snapshot
Utility methods for interacting with the snapshot referenced files.
SnapshotReferenceUtil.FileVisitor - 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
SNAPSHOTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
SnapshotSentinel - Interface in org.apache.hadoop.hbase.master
Watch the current snapshot under process
SnapshotTask - Class in org.apache.hadoop.hbase.snapshot
General snapshot operation taken on a regionserver
SnapshotTask(HBaseProtos.SnapshotDescription, ForeignExceptionDispatcher) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotTask
 
socket - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
socket - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.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)
socketFactory - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
socketSendBufferSize - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
socketTimeout - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
SoftValueSortedMap<K,V> - Class in org.apache.hadoop.hbase.util
A SortedMap implementation that uses Soft Reference values internally to make it play well with the GC when in a low-memory situation.
SoftValueSortedMap() - Constructor for class org.apache.hadoop.hbase.util.SoftValueSortedMap
Constructor
SoftValueSortedMap(Comparator<K>) - Constructor for class org.apache.hadoop.hbase.util.SoftValueSortedMap
Constructor
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
 
sortedPrefixes - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
SORTEDPREFIXES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.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 class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
SOURCE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
SOURCE_LOG_EDITS_FILTERED - Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
SOURCE_LOG_EDITS_READ - Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
SOURCE_SHIPPED_BATCHES - Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
SOURCE_SHIPPED_OPS - Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
SOURCE_SIZE_OF_LOG_QUEUE - Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
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.
SpanReceiverHost(Configuration) - Constructor for class org.apache.hadoop.hbase.trace.SpanReceiverHost
 
SPEC_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
split(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Split a table or an individual region.
split(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Split a table or an individual region.
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 a table or an individual region.
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() - Method in class org.apache.hadoop.hbase.KeyValue
 
split(AdminProtocol, HRegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to split a region using admin protocol.
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.HexStringSplit
 
split(int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
 
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[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
split(int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
split2(BigInteger, BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
Divide 2 numbers in half (for split algorithm)
SPLIT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
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_POLICY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
SPLIT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
SPLIT_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
SPLIT_SKIP_ERRORS_DEFAULT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.HLog
 
SPLIT_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
SPLIT_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
SPLIT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
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
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
 
SPLITKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
SPLITKEYS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
splitLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
splitLog(List<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
splitLog(List<ServerName>, PathFilter) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
This method is the base split method that splits HLog files matching a filter.
splitLog() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
Split 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.
splitLog(CountDownLatch) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
Split 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.
splitLogAfterStartup(MasterFileSystem) - Method in class org.apache.hadoop.hbase.master.HMaster
Override to change master's splitLogAfterStartup.
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(List<Path>, PathFilter) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
The caller will block until all the 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) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
Splits a HLog file into region's recovered-edits directory
splitLogFile(Path, FileStatus, FileSystem, Configuration, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
Splits a HLog file into region's recovered-edits directory
splitLogFile(FileStatus, CancelableProgressable) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
 
SplitLogManager - Class in org.apache.hadoop.hbase.master
Distributes the task of log splitting to the available region servers.
SplitLogManager(ZooKeeperWatcher, Configuration, Stoppable, MasterServices, ServerName) - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager
Wrapper around SplitLogManager.SplitLogManager(ZooKeeperWatcher zkw, Configuration conf, Stoppable stopper, MasterServices master, ServerName serverName, TaskFinisher tf) that provides a task finisher for copying recovered edits to their final destination.
SplitLogManager(ZooKeeperWatcher, Configuration, Stoppable, MasterServices, ServerName, SplitLogManager.TaskFinisher) - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager
Its OK to construct this object even when region-servers are not online.
SplitLogManager.TaskFinisher - Interface in org.apache.hadoop.hbase.master
SplitLogManager can use objects implementing this interface to finish off a partially done task by SplitLogWorker.
SplitLogManager.TaskFinisher.Status - Enum in org.apache.hadoop.hbase.master
status that can be returned finish()
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) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Done
 
SplitLogTask.Err - Class in org.apache.hadoop.hbase
 
SplitLogTask.Err(ServerName) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Err
 
SplitLogTask.Owned - Class in org.apache.hadoop.hbase
 
SplitLogTask.Owned(ServerName) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Owned
 
SplitLogTask.Resigned - Class in org.apache.hadoop.hbase
 
SplitLogTask.Resigned(ServerName) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Resigned
 
SplitLogTask.Unassigned - Class in org.apache.hadoop.hbase
 
SplitLogTask.Unassigned(ServerName) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Unassigned
 
SplitLogWorker - Class in org.apache.hadoop.hbase.regionserver
This worker is spawned in every regionserver (should we also spawn one in the master?).
SplitLogWorker(ZooKeeperWatcher, Configuration, ServerName, SplitLogWorker.TaskExecutor) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
 
SplitLogWorker(ZooKeeperWatcher, Configuration, ServerName, LastSequenceId) - 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
 
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 HLog
SPLITPOINT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
splitRegion(CatalogTracker, HRegionInfo, HRegionInfo, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Splits the region into two in an atomic operation.
splitRegion(RpcController, AdminProtos.SplitRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
 
splitRegion(RpcController, AdminProtos.SplitRegionRequest, RpcCallback<AdminProtos.SplitRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
 
splitRegion(RpcController, AdminProtos.SplitRegionRequest, RpcCallback<AdminProtos.SplitRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
splitRegion(RpcController, AdminProtos.SplitRegionRequest, RpcCallback<AdminProtos.SplitRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
splitRegion(RpcController, AdminProtos.SplitRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Split a region on the region server.
SplitRegionHandler - Class in org.apache.hadoop.hbase.master.handler
Handles SPLIT region event on Master.
SplitRegionHandler(Server, AssignmentManager, HRegionInfo, ServerName, List<HRegionInfo>) - Constructor for class org.apache.hadoop.hbase.master.handler.SplitRegionHandler
 
splitStoreFile(LoadIncrementalHFiles.LoadQueueItem, HTable, byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
 
SPLITTING_EXT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.HLog
File Extension used while splitting an HLog into regions (HBASE-2312)
SPLITTING_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
SplitTransaction - Class in org.apache.hadoop.hbase.regionserver
Executes region split as a "transaction".
SplitTransaction(HRegion, byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransaction
Constructor
srcDir - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
 
STACKTRACE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
STAMP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
stampSet - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
start() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
Start monitoring for archive updates
start() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
Starts the catalog tracker.
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.constraint.ConstraintProcessor
 
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.BaseMasterObserver
 
start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
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.example.BulkDeleteEndpoint
 
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.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.ipc.HBaseServer
Starts the service.
start() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
 
START - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
Deprecated. 
start(ProcedureCoordinator) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
Initialize and start threads necessary to connect an implementation's rpc mechanisms.
start(ProcedureMember) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
Initialize and start any threads or connections the member needs.
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(ProcedureMember) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
 
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(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() - Method in class org.apache.hadoop.hbase.util.HasThread
 
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.RegionServerTracker
Starts the tracking of online RegionServers.
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
 
startCacheFlush(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
WAL keeps track of the sequence numbers that were not yet flushed from memstores in order to be able to do cleanup.
startCancel() - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
 
startCancel() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
startCatalogJanitorChore() - Method in class org.apache.hadoop.hbase.master.HMaster
Useful for testing purpose also where we have master restart scenarios.
STARTCODE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
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
STARTDATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
startDelay(boolean) - Method in interface org.apache.hadoop.hbase.ipc.Delayable
Signal that the call response should be delayed, thus freeing the RPC server to handle different requests.
startDelay(boolean) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
startExecutorService(ExecutorType, int) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
 
STARTKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
STARTKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
 
startMonitoring() - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
Deprecated.  
startProcedure(ForeignExceptionDispatcher, String, byte[], List<String>) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
Kick off the named procedure
startRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
This method needs to be called before any public call that reads or modifies data.
startRegionServer(HRegionServer) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
startRegionServer(HRegionServer, String) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
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.thrift2.generated.TScan
 
STARTROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
STARTROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
startStateTracker(ZooKeeperWatcher, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
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.
startThreads() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Starts the service threads but does not allow requests to be responded yet.
startThreads() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
 
startTime - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
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
 
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
 
startWriting(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
Starts writing into the block.
state - Variable in enum org.apache.hadoop.hbase.security.SaslStatus
 
STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
StateDumpServlet - Class in org.apache.hadoop.hbase.monitoring
 
StateDumpServlet() - Constructor for class org.apache.hadoop.hbase.monitoring.StateDumpServlet
 
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
 
STATS_RECORD_SEP - Static variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Record separator for the Bloom filter statistics human-readable string
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_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_PUBLISHER_CLASS - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
The implementation class used to publish the status.
std(byte[], 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_DEV_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
stepDownAsLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated. Removes the leader znode, if it is currently claimed by this instance.
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
 
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 class org.apache.hadoop.hbase.catalog.CatalogTracker
Stop working.
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
 
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.BaseRowProcessorEndpoint
 
stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
 
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.MultiRowMutationEndpoint
 
stop(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
 
stop() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
Stop all threads related to this client.
stop() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
Stops the service.
stop() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
 
stop() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
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(String) - Method in class org.apache.hadoop.hbase.master.HMaster
 
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.SnapshotLogCleaner
 
stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
stop() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
 
stop(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionsCleaner
 
stop(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
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.replication.master.ReplicationLogCleaner
 
stop() - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
 
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(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.zookeeper.ZooKeeperNodeTracker
 
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.
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, MasterAdminProtos.StopMasterRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
stopMaster(RpcController, MasterAdminProtos.StopMasterRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
stopMaster(RpcController, MasterAdminProtos.StopMasterRequest, RpcCallback<MasterAdminProtos.StopMasterResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
stopMaster(RpcController, MasterAdminProtos.StopMasterRequest, RpcCallback<MasterAdminProtos.StopMasterResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
stopMaster(RpcController, MasterAdminProtos.StopMasterRequest, RpcCallback<MasterAdminProtos.StopMasterResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
stopMonitoring() - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
Deprecated.  
Stoppable - Interface in org.apache.hadoop.hbase
Implementers are Stoppable.
stopped - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
stopper - Variable in class org.apache.hadoop.hbase.Chore
 
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.
stopRow - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
STOPROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
STOPROWKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
stopServer(RpcController, AdminProtos.StopServerRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
 
stopServer(RpcController, AdminProtos.StopServerRequest, RpcCallback<AdminProtos.StopServerResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
 
stopServer(RpcController, AdminProtos.StopServerRequest, RpcCallback<AdminProtos.StopServerResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
 
stopServer(RpcController, AdminProtos.StopServerRequest, RpcCallback<AdminProtos.StopServerResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
 
stopServer(RpcController, AdminProtos.StopServerRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Stop the region server.
StorageClusterStatusMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus.Node - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus.Node.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus.Region - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
StorageClusterStatusMessage.StorageClusterStatus.Region.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
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.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.
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<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, HFileDataBlockEncoder) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile
Constructor, loads a reader and it's indices, etc.
StoreFile(FileSystem, StoreFileInfo, Configuration, CacheConfig, BloomType, HFileDataBlockEncoder) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile
Constructor, loads a reader and it's indices, etc.
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, DataBlockEncoding) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
StoreFile.Reader(FileSystem, Path, FSDataInputStream, FSDataInputStream, long, CacheConfig, DataBlockEncoding, boolean) - 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, int) - 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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
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_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.protobuf.generated.HBaseProtos.RegionLoad
 
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
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.
STOREFILES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
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) - 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.protobuf.generated.HBaseProtos.RegionLoad
 
STOREFILESIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
storeLimit - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
STORELIMIT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
STORELIMIT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
storeOffset - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
STOREOFFSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
STOREOFFSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
stores - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
STORES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
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, boolean, Scan, NavigableSet<byte[]>, long, int) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
An internal constructor.
StoreScanner(Store, ScanInfo, Scan, NavigableSet<byte[]>) - 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_PARALLEL_SEEK_ENABLE - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
STOREUNCOMPRESSEDSIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
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
 
STRING - Static variable in class org.apache.hadoop.hbase.util.ClassSize
String overhead
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
 
strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
 
strToRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
 
strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
 
subMap(K, K) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
submit(EventHandler) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
 
submitMaxNodeDepthCandidate(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
 
submitSubprocedure(Subprocedure) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
Submit an subprocedure for execution.
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(E, E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
SUBSTR_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
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 - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_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.get_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.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_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_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
sum(byte[], 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.
summarize() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
 
sumOfMillisSecBetweenNexts - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
sum of milliseconds between sequential next calls
SUPERUSER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
Configuration key for superusers
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
 
suspendEncoding() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Suspends encoding of the stream.
SWITCH_TO_SIMPLE_AUTH - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
 
switchBalancer(boolean, HMaster.BalanceSwitchMode) - Method in class org.apache.hadoop.hbase.master.HMaster
Assigns balancer switch according to BalanceSwitchMode
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 interface org.apache.hadoop.hbase.regionserver.wal.HLog
 
sync(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
 
sync() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Writer
 
sync() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
 
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
 
SYNCHRONOUS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
synchronousBalanceSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 

T

TAB - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for tab
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.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.get_args
the table to get from
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.increment_args
the table to increment the value on
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
TABLE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
TABLE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
table_jsp - Class in org.apache.hadoop.hbase.generated.master
 
table_jsp() - Constructor for class org.apache.hadoop.hbase.generated.master.table_jsp
 
TABLE_LOCK_ENABLE - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
Configuration key for enabling table-level locks for schema changes
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_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
TableAddFamilyHandler - Class in org.apache.hadoop.hbase.master.handler
Handles adding a new family to an existing table.
TableAddFamilyHandler(byte[], HColumnDescriptor, Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.TableAddFamilyHandler
 
TableAuthManager - Class in org.apache.hadoop.hbase.security.access
Performs authorization checks for a given user's assigned permissions
tableDeleted(byte[]) - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
 
tableDeleted(byte[]) - Method in class org.apache.hadoop.hbase.master.TableLockManager
Called after a table has been deleted, and after the table lock is released.
TableDeleteFamilyHandler - Class in org.apache.hadoop.hbase.master.handler
Handles adding a new family to an existing table.
TableDeleteFamilyHandler(byte[], byte[], Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.TableDeleteFamilyHandler
 
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.
TableEventHandler - Class in org.apache.hadoop.hbase.master.handler
Base class for performing operations against tables.
TableEventHandler(EventType, byte[], Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
tableExists(CatalogTracker, String) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
Checks if the specified table exists.
tableExists(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
tableExists(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
TableExistsException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when a table exists but should not
TableExistsException() - Constructor for exception org.apache.hadoop.hbase.exceptions.TableExistsException
default constructor
TableExistsException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.TableExistsException
Constructor
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.
TABLEINFO_NAME - Static variable in class org.apache.hadoop.hbase.util.FSTableDescriptors
The file name used to store HTD in HDFS
TableInfoCopyTask - Class in org.apache.hadoop.hbase.snapshot
Copy the table info into the snapshot directory
TableInfoCopyTask(ForeignExceptionDispatcher, HBaseProtos.SnapshotDescription, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.snapshot.TableInfoCopyTask
Copy the table info for the given table into the snapshot
TableInfoMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableInfoMessage.TableInfo - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableInfoMessage.TableInfo.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableInfoMessage.TableInfo.Region - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableInfoMessage.TableInfo.Region.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
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.exceptions
Failed to find .tableinfo file under table dir
TableInfoMissingException() - Constructor for exception org.apache.hadoop.hbase.exceptions.TableInfoMissingException
 
TableInfoMissingException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.TableInfoMissingException
 
TableInfoMissingException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.TableInfoMissingException
 
TableInfoMissingException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.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
Deprecated. 
TableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormat
Deprecated.  
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
Deprecated. 
TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Deprecated.  
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
 
TableListMessage.TableList.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
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
 
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.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
Deprecated. 
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
Deprecated. 
TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Deprecated.  
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
TableModifyFamilyHandler - Class in org.apache.hadoop.hbase.master.handler
Handles adding a new family to an existing table.
TableModifyFamilyHandler(byte[], HColumnDescriptor, Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.TableModifyFamilyHandler
 
tableName - Variable in class org.apache.hadoop.hbase.client.ServerCallable
 
tableName - Variable in class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
TABLENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
TABLENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
TABLENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
TABLENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
TABLENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
TABLENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
TABLENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
TABLENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
TABLENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
TABLENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
TABLENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
TABLENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
TABLENAMES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
tableNameStr - Variable in class org.apache.hadoop.hbase.master.handler.TableEventHandler
 
TableNotDisabledException - Exception in org.apache.hadoop.hbase.exceptions
Thrown if a table should be offline but is not
TableNotDisabledException() - Constructor for exception org.apache.hadoop.hbase.exceptions.TableNotDisabledException
default constructor
TableNotDisabledException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.TableNotDisabledException
Constructor
TableNotDisabledException(byte[]) - Constructor for exception org.apache.hadoop.hbase.exceptions.TableNotDisabledException
 
TableNotEnabledException - Exception in org.apache.hadoop.hbase.exceptions
Thrown if a table should be enabled but is not
TableNotEnabledException() - Constructor for exception org.apache.hadoop.hbase.exceptions.TableNotEnabledException
default constructor
TableNotEnabledException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.TableNotEnabledException
Constructor
TableNotEnabledException(byte[]) - Constructor for exception org.apache.hadoop.hbase.exceptions.TableNotEnabledException
 
TableNotFoundException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when a table can not be located
TableNotFoundException() - Constructor for exception org.apache.hadoop.hbase.exceptions.TableNotFoundException
default constructor
TableNotFoundException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.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
Deprecated. 
TableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat
Deprecated.  
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
Deprecated. Convert Reduce output (key, value) to (HStoreKey, KeyedDataArrayWritable) and write to an HBase table
TableOutputFormat.TableRecordWriter(HTable) - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
Deprecated. Instantiate a TableRecordWriter with the HBase HClient for writing.
TableOutputFormat.TableRecordWriter<KEY> - Class in org.apache.hadoop.hbase.mapreduce
Writes the reducer output to an HBase table.
TableOutputFormat.TableRecordWriter(HTable) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
Instantiate a TableRecordWriter with the HBase HClient for writing.
TablePartiallyOpenException - Exception in org.apache.hadoop.hbase.exceptions
Thrown if a table should be online/offline but is partially open
TablePartiallyOpenException() - Constructor for exception org.apache.hadoop.hbase.exceptions.TablePartiallyOpenException
 
TablePartiallyOpenException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.TablePartiallyOpenException
 
TablePartiallyOpenException(byte[]) - Constructor for exception org.apache.hadoop.hbase.exceptions.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(byte[], 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(byte[], 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 qualifer, allowing the assigned actions to be performed.
TablePermission(byte[], 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.
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
Deprecated. 
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
TABLESCHEMA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
TABLESCHEMA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
TABLESCHEMA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
TableSchemaMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableSchemaMessage.TableSchema - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableSchemaMessage.TableSchema.Attribute - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableSchemaMessage.TableSchema.Attribute.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableSchemaMessage.TableSchema.AttributeOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
 
TableSchemaMessage.TableSchema.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
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
tablesDetailed_jsp - Class in org.apache.hadoop.hbase.generated.master
 
tablesDetailed_jsp() - Constructor for class org.apache.hadoop.hbase.generated.master.tablesDetailed_jsp
 
TableSplit - Class in org.apache.hadoop.hbase.mapred
Deprecated. 
TableSplit() - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated. default constructor
TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated. Constructor
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
Creates a new instance while assigning all variables.
TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
Creates a new instance without a scanner.
tableZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
tail(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
tailMap(K) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
tailSet(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
take() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
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 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) - Constructor for class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
TakeSnapshotUtils - Class in org.apache.hadoop.hbase.snapshot
Utilities for useful when taking a snapshot
TaskMonitor - Class in org.apache.hadoop.hbase.monitoring
Singleton which keeps track of tasks going on in this VM.
TaskMonitor() - Constructor for class org.apache.hadoop.hbase.monitoring.TaskMonitor
 
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() - 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
 
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
 
TColumn - Class in org.apache.hadoop.hbase.thrift2.generated
Addresses a single cell or multiple cells in a HBase table by column family and optionally a column qualifier and timestamp
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.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
Represents a single cell and the amount to increment it by
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
Represents a single cell and its value.
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.
tcpKeepAlive - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
tcpKeepAlive - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
tcpNoDelay - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
tcpNoDelay - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
TDelete - Class in org.apache.hadoop.hbase.thrift2.generated
Used to perform Delete operations on a single row.
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._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.
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.
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) - 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
TEST_SKIP - Static variable in class org.apache.hadoop.hbase.master.handler.SplitRegionHandler
For testing only! Set to true to skip handling of split.
TEST_TRIGGER_DFS_APPEND - Static variable in class org.apache.hadoop.hbase.util.FSHDFSUtils
 
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
 
TGet - Class in org.apache.hadoop.hbase.thrift2.generated
Used to perform Get operations on a single row.
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._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 - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService
 
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.checkAndDelete_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.checkAndDelete_call(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete, AsyncMethodCallback<THBaseService.AsyncClient.checkAndDelete_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndDelete_call
 
THBaseService.AsyncClient.checkAndPut_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.checkAndPut_call(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut, AsyncMethodCallback<THBaseService.AsyncClient.checkAndPut_call>, 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<THBaseService.AsyncClient.closeScanner_call>, 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<THBaseService.AsyncClient.deleteMultiple_call>, 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<THBaseService.AsyncClient.deleteSingle_call>, 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<THBaseService.AsyncClient.exists_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.exists_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<THBaseService.AsyncClient.get_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.get_call
 
THBaseService.AsyncClient.getMultiple_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.getMultiple_call(ByteBuffer, List<TGet>, AsyncMethodCallback<THBaseService.AsyncClient.getMultiple_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getMultiple_call
 
THBaseService.AsyncClient.getScannerRows_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.getScannerRows_call(int, int, AsyncMethodCallback<THBaseService.AsyncClient.getScannerRows_call>, 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<THBaseService.AsyncClient.increment_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.increment_call
 
THBaseService.AsyncClient.openScanner_call - Class in org.apache.hadoop.hbase.thrift2.generated
 
THBaseService.AsyncClient.openScanner_call(ByteBuffer, TScan, AsyncMethodCallback<THBaseService.AsyncClient.openScanner_call>, 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<THBaseService.AsyncClient.put_call>, 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<THBaseService.AsyncClient.putMultiple_call>, 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.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.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.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.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.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.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.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.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.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.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.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.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.
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
 
THREADID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
ThreadLocalEncoderPool - Class in org.apache.hadoop.hbase.codec.prefixtree.encode
Pool to enable reusing the Encoder objects which can consist of thousands of smaller objects and would be more garbage than the data in the block.
ThreadLocalEncoderPool() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.ThreadLocalEncoderPool
 
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
 
thresholdIdleConnections - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
 
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_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.
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(Configuration, ThriftServerRunner.HBaseHandler) - 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 HBaseAdmin and HTable objects.
ThriftServerRunner.HBaseHandler() - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
Constructs an HBaseHandler object.
ThriftServerRunner.HBaseHandler(Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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.DefaultCompactionPolicy
 
throttleCompaction(long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
throttleCompaction(long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
throwExceptionIfCallerDisconnected() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
throwExceptionIfCallerDisconnected() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
Throw an exception if the caller who made this IPC call has disconnected.
thrown - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
 
TIllegalArgument - Exception in org.apache.hadoop.hbase.thrift2.generated
A TIllegalArgument exception indicates an illegal or invalid argument was passed into a procedure.
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.
timedOut(long) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
 
timeInQueue() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
 
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
 
timeoutMonitor - Variable in class org.apache.hadoop.hbase.master.AssignmentManager
 
TimeRange - Class in org.apache.hadoop.hbase.io
Represents an interval of version timestamps.
TimeRange() - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Default constructor.
TimeRange(long) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Represents interval [minStamp, Long.MAX_VALUE)
TimeRange(byte[]) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Represents interval [minStamp, Long.MAX_VALUE)
TimeRange(long, long) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Represents interval [minStamp, maxStamp)
TimeRange(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
Represents interval [minStamp, maxStamp)
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
TIMERANGE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
TIMERANGE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
TIMERANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Key for Timerange information in metadata
timeRangeTracker - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
TimeRangeTracker - Class in org.apache.hadoop.hbase.regionserver
Stores the minimum and maximum timestamp values (both are inclusive).
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
 
timestamp - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
timestamp - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
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.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
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
 
TimeStampingFileContext - Class in org.apache.hadoop.hbase.metrics.file
Deprecated. 
TimeStampingFileContext() - Constructor for class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
Deprecated.  
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
 
TIMESTAMPS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
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 those cells whose timestamp (version) is in the specified list of timestamps.
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 hlog to determine if it should be deleted.
TimeToLiveLogCleaner() - Constructor for class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
 
TIncrement - Class in org.apache.hadoop.hbase.thrift2.generated
Used to perform Increment operations for a single row.
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.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.HBaseServer.Call
 
TIOError - Exception in org.apache.hadoop.hbase.thrift2.generated
A TIOError exception signals that an error occurred communicating to the HBase master or a HBase region server.
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.
TO_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
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.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
 
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
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
Reverses Bytes.toBytes(boolean)
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.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.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
 
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.MultipleColumnPrefixFilter
 
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(int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
toByteArray() - Method in class org.apache.hadoop.hbase.RegionTransition
 
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(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) - 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(Cell) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
toCell(HBaseProtos.Cell) - 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
toContextString() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
 
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
 
toException(HBaseProtos.NameBytesPair) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a stringified protocol buffer exception Parameter to a Java Exception
toFilter(HBaseProtos.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"
toGet(ClientProtos.Get) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protocol buffer Get to a client Get
toGet(Get) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Create a protocol buffer Get based on a client Get.
toHLogEntries(List<AdminProtos.WALEntry>) - Static method in class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
Get the HLog entries from a list of protocol buffer WALEntry
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
toIOException(ServiceException) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Unwraps an exception from a protobuf service into the underlying (expected) IOException.
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() - 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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
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
 
tokenHandlers - Static variable in class org.apache.hadoop.hbase.ipc.HBaseClient
 
TokenInfo - Annotation Type in org.apache.hadoop.hbase.security
Indicates Token related information to be used in authorizing connections over a given RPC protocol interface.
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.
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) - 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
Create a protocol buffer Mutate 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.
TOP_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
 
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.
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.
toResult(Result) - 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) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
 
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
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
toString() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionKey
 
toString() - Method in class org.apache.hadoop.hbase.client.Increment
 
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.Result
 
toString() - Method in class org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
 
toString() - Method in class org.apache.hadoop.hbase.ClusterId
 
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() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
toString(int) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
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.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.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.FileLink
 
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.BlockCacheColumnFamilySummary
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
toString() - Method in exception org.apache.hadoop.hbase.io.hfile.bucket.CacheFullException
 
toString() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
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.HFileDataBlockEncoderImpl
 
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.HBaseClient.Call
 
toString() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.ConnectionId
 
toString() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
 
toString() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
 
toString() - Method in class org.apache.hadoop.hbase.KeyValue
 
toString() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
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.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.DeleteTableHandler
 
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.MergedRegionHandler
 
toString() - Method in class org.apache.hadoop.hbase.master.handler.MetaServerShutdownHandler
 
toString() - Method in class org.apache.hadoop.hbase.master.handler.ModifyTableHandler
 
toString() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
 
toString() - Method in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
 
toString() - Method in class org.apache.hadoop.hbase.master.handler.SplitRegionHandler
 
toString() - Method in class org.apache.hadoop.hbase.master.handler.TableAddFamilyHandler
 
toString() - Method in class org.apache.hadoop.hbase.master.handler.TableDeleteFamilyHandler
 
toString() - Method in class org.apache.hadoop.hbase.master.handler.TableModifyFamilyHandler
 
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.monitoring.MonitoredRPCHandlerImpl
 
toString() - Method in class org.apache.hadoop.hbase.RegionLoad
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
 
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.MemStoreLAB.Allocation
 
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.TimeRangeTracker
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog.Entry
 
toString() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
 
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.rest.model.ColumnSchemaModel
 
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.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.User
 
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.thrift.TBoundedThreadPoolServer.Args
 
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.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.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.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.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.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.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 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.TScan
 
toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
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.ByteRange
 
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, 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.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.Pair
 
toString() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
toString() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
 
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.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.ZooKeeperWatcher
 
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.
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
 
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.regionserver.wal.HLogKey
Produces a string map for this key.
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
 
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_hlogs - 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_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_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
 
toTablePermission(AccessControlProtos.Permission) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Converts a Permission proto to a client TablePermission object.
TOTAL_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
TOTAL_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
 
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.protobuf.generated.HBaseProtos.RegionLoad
 
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
 
TOTALNUMBEROFREQUESTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
totalOps - Variable in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
Deprecated.  
TOTALREGIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
TOTALSTATICBLOOMSIZEKB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
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.protobuf.generated.HBaseProtos.RegionLoad
 
TOTALSTATICINDEXSIZEKB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
totalUncompressedBytes - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
Total uncompressed bytes, maybe calculate a compression ratio later.
TOTALUNCOMPRESSEDBYTES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
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.
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.
touch() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
Update lastActivity with the current time.
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.
toUserTablePermissions(ListMultimap<String, TablePermission>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a ListMultimap where key is username to a protobuf UserPermission
toUserTablePermissions(AccessControlProtos.UserTablePermissions) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
Convert a protobuf UserTablePermissions to a ListMultimap where key is username.
TPut - Class in org.apache.hadoop.hbase.thrift2.generated
Used to perform Put operations for a single row.
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.
TRACE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
TRACEID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
TRACEINFO_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
Tracing - Class in org.apache.hadoop.hbase.protobuf.generated
 
Tracing.RPCTInfo - Class in org.apache.hadoop.hbase.protobuf.generated
 
Tracing.RPCTInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
Tracing.RPCTInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
trackTimestamps(KeyValue) - 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
 
transferQueues(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Transfer all the queues of the specified to this region server.
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.Filter
Give the filter a chance to transform the passed KeyValue.
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterBase
By default no transformation takes place
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
transformClusterKey(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Separate the given key into the three configurations it should contain: hbase.zookeeper.quorum, hbase.zookeeper.client.port and zookeeper.znode.parent
TRANSITIONINZK_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
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
 
translateException(Throwable) - Static method in class org.apache.hadoop.hbase.client.ServerCallable
Get the good or the remote exception if any, throws the DoNotRetryIOException.
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
TResult - Class in org.apache.hadoop.hbase.thrift2.generated
if no Result is found, row and columnValues will not be set.
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.HStore
 
triggerMajorCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
triggerNow() - Method in class org.apache.hadoop.hbase.Chore
If the thread is currently sleeping, trigger the core to happen immediately.
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
 
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.
tryAtomicRegionLoad(HConnection, byte[], 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.
tryStartOffPeakRequest() - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakCompactions
Tries making the compaction off-peak.
tryTransitionFromOfflineToFailedOpen(RegionServerServices, HRegionInfo, int) - Static method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
Try to transition to open.
ts - Variable in class org.apache.hadoop.hbase.client.Mutation
 
TScan - Class in org.apache.hadoop.hbase.thrift2.generated
Any timestamps in the columns are ignored, use timeRange to select by timestamp.
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.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
 
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_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
 
TTL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
TTL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
 
type - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
TYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
TYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
TYPE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
Size of the key type field in bytes
typeBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
TYPES - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
static

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.security.User
 
unassign(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Unassign a region from current hosting regionserver.
unassign(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Unassign the list of regions.
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
 
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
 
UNASSIGNED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
 
unassignRegion(RpcController, MasterAdminProtos.UnassignRegionRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
unassignRegion(RpcController, MasterAdminProtos.UnassignRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.BlockingInterface
 
unassignRegion(RpcController, MasterAdminProtos.UnassignRegionRequest, RpcCallback<MasterAdminProtos.UnassignRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Interface
 
unassignRegion(RpcController, MasterAdminProtos.UnassignRegionRequest, RpcCallback<MasterAdminProtos.UnassignRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService.Stub
 
unassignRegion(RpcController, MasterAdminProtos.UnassignRegionRequest, RpcCallback<MasterAdminProtos.UnassignRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MasterAdminService
 
UNCOMPRESSEDDATAINDEXSIZE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
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_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.exceptions
Thrown when we are asked to operate on a region we know nothing about.
UnknownRegionException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownRegionException
 
UnknownScannerException - Exception in org.apache.hadoop.hbase.exceptions
Thrown if a region server is passed an unknown scanner id.
UnknownScannerException() - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownScannerException
constructor
UnknownScannerException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownScannerException
Constructor
UnknownSnapshotException - Exception in org.apache.hadoop.hbase.exceptions
Exception thrown when we get a request for a snapshot we don't recognize.
UnknownSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownSnapshotException
 
UnknownSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownSnapshotException
 
UnmodifyableHColumnDescriptor - Class in org.apache.hadoop.hbase.client
Immutable HColumnDescriptor
UnmodifyableHColumnDescriptor(HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
 
UnmodifyableHTableDescriptor - Class in org.apache.hadoop.hbase.client
Read-only table descriptor.
UnmodifyableHTableDescriptor() - Constructor for class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
Default constructor
unregisterListener(EventType) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
Stop receiving updates before and after processing instances of EventType
unregisterListener(ZooKeeperListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
unregisterWALActionsListener(WALActionsListener) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
unregisters WALActionsListener
unsetAmount() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
unsetCaching() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
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
 
unsetDeletes() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
unsetDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
unsetDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
unsetDeleteType() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
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.checkAndPut_args
 
unsetGet() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
unsetGet() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
unsetGets() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
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
 
unsetIncrement() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
unsetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_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.get_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.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.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
 
unsetMaxStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
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.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
 
unsetNumRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
unsetPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
unsetPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
unsetPuts() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
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.checkAndPut_args
 
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.checkAndPut_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
 
unsetScan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_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
 
unsetStartRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetStopRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
unsetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_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.get_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.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.thrift2.generated.THBaseService.checkAndDelete_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.get_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.increment_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
 
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.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
 
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.checkAndPut_args
 
unsetWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
unsetWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
unsetWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
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.
update(byte[], byte[], R) - Method in interface org.apache.hadoop.hbase.client.coprocessor.Batch.Callback
 
update(String) - Method in class org.apache.hadoop.hbase.metrics.ExactCounterMetric
Deprecated.  
update(String, long) - Method in class org.apache.hadoop.hbase.metrics.ExactCounterMetric
Deprecated.  
update(int) - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
update(long) - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
Deprecated.  
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.ScanDeleteTracker
 
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(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
 
updateCandidateFilesForRowKeyBefore(Iterator<StoreFile>, KeyValue, KeyValue) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Updates the candidate list for finding row key before.
updateColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Used in tests.
updateDelete() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
updateDelete(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
 
updateExistingNodeData(ZooKeeperWatcher, String, byte[], int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Deprecated. Unused
updateGet() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
updateGet(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() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
Update related counts of gets.
updateGet() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
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
 
updateIncrement() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
updateIncrement(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
 
updateKeyInZK(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
updateLatestStamp(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
 
updateMetaLocation(CatalogTracker, HRegionInfo, ServerName, long) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Updates the location of the specified META region in ROOT to be the specified server hostname and startcode.
updatePut() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
updatePut(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
 
updateQuantile(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Add some value to a Quantile (An accurate histogram).
updateQuantile(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
updateReaders() - Method in interface org.apache.hadoop.hbase.regionserver.ChangedReadersObserver
Notify observers.
updateReaders() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
updateRegionInfo(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
updateRegionLocation(CatalogTracker, HRegionInfo, ServerName, long) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
Updates the location of the specified region in 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.
updateRITCount(int) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
set new value for number of regions in transition.
updateRITCountOverThreshold(int) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
update RIT count that are in this state for more than the threshold as defined by the property rit.metrics.threshold.time.
updateRITOldestAge(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
update the timestamp for oldest region in transition metrics.
updateRootAndMetaIfNecessary(MasterServices) - Static method in class org.apache.hadoop.hbase.catalog.MetaMigrationConvertingToPB
Deprecated. Update ROOT and META to newer version, converting writable serialization to PB, if it is needed.
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
 
updateSizeMetrics(CachedBlock, 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 CachedBlock
updateSplitSize(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
updateSplitSize(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
 
updateSplitTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
updateSplitTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
 
updateTimestampToNow() - Method in class org.apache.hadoop.hbase.master.RegionState
 
upsert(Iterable<? extends Cell>, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
upsert(Iterable<? extends Cell>, long) - Method in class org.apache.hadoop.hbase.regionserver.MemStore
Update or insert the specified KeyValues.
upsert(Iterable<? extends Cell>, long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
Adds or replaces the specified KeyValues.
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.
USEDHEAPMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
useEncodedScanner(boolean) - 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(boolean) - 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?
user - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
USER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
USER_REGION_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
useRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
 
USERINFO_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
username - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
USERNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
USERNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
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[], byte[], 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[], byte[], 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[], byte[], 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.
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_PORT_REGEX - Static variable in class org.apache.hadoop.hbase.util.Addressing
 
VALID_USER_TABLE_REGEX - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
 
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 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.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.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.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.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.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.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 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.TScan
 
validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
validateHLogFilename(String) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogUtil
 
validateInput(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
Deprecated.  
validatePut(Put) - 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.
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.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.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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
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.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
 
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.IsolationLevel
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.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.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.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.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.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.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.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.TaskFinisher.Status
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.protobuf.generated.AccessControlProtos.Permission.Action
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.ScopeType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.ScopeType
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.ScopeType
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CellType
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
 
valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
 
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.RegionOpeningState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ScanQueryMatcher.MatchCode
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.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.HBaseSaslRpcServer.QualityOfProtection
Returns the enum constant of this type with the specified name.
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.snapshot.ExportSnapshot.Counter
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.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.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.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.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.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.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.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.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.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.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.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.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.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.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
 
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.IsolationLevel
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.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.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.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.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.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() - 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.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.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.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.protobuf.generated.AccessControlProtos.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.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
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.protobuf.generated.AdminProtos.OpenRegionResponse.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.protobuf.generated.AdminProtos.WALEntry.WALEdit.ScopeType
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.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
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.protobuf.generated.ClientProtos.MutationProto.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.protobuf.generated.ClientProtos.MutationProto.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.protobuf.generated.ClusterStatusProtos.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.protobuf.generated.ComparatorProtos.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.protobuf.generated.FilterProtos.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.protobuf.generated.FSProtos.Reference.Range
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.protobuf.generated.HBaseProtos.CellType
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.protobuf.generated.HBaseProtos.CompareType
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.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
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.protobuf.generated.HBaseProtos.SnapshotDescription.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.protobuf.generated.ZooKeeperProtos.ReplicationState.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.protobuf.generated.ZooKeeperProtos.SplitLogTask.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.protobuf.generated.ZooKeeperProtos.Table.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.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.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.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.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.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.HBaseSaslRpcServer.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.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.TTimeRange._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.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() - 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() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
 
VALUES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
verify(byte[], byte[], Set<byte[]>) - Method in class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
Checks that columns for a rowKey and cf are valid if generated via LoadTestDataGenerator.generateColumnsForCf(byte[], byte[])
verify(byte[], byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
Checks that value for a rowKey/cf/column is valid if generated via LoadTestDataGenerator.generateValue(byte[], byte[], byte[])
verify(byte[], byte[]...) - Static method in class org.apache.hadoop.hbase.util.test.LoadTestKVGenerator
Verifies that the given byte array is the same as what would be generated for the given seed strings (row/cf/column/...).
verifyAllLogsGotReferenced(FileSystem, Path, Set<String>, HBaseProtos.SnapshotDescription, Path) - Static method in class org.apache.hadoop.hbase.snapshot.TakeSnapshotUtils
Verify that all the expected logs got referenced
verifyMetaRegionLocation(long) - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
Verify .META. is deployed and accessible.
verifyRecoveredEdits(FileSystem, Path, HRegionInfo, HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.TakeSnapshotUtils
Verify one of a snapshot's region's recovered.edits, has been at the surface (file names, length), match the original directory.
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
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 - 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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
VERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
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
 
VersionAnnotation - Annotation Type in org.apache.hadoop.hbase
A package attribute that captures the version of hbase that was compiled.
VersionInfo - Class in org.apache.hadoop.hbase.util
This class finds the package info for hbase and the VersionAnnotation information.
VersionInfo() - Constructor for class org.apache.hadoop.hbase.util.VersionInfo
 
VersionMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
VersionMessage.Version - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
VersionMessage.Version.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
 
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
VERSIONOFCLOSINGNODE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
VERSIONOFOFFLINENODE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
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
 
visit(Result) - Method in interface org.apache.hadoop.hbase.catalog.MetaReader.Visitor
Visit the catalog table row.
visitLogEntryBeforeWrite(HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
Called before each write.
visitLogEntryBeforeWrite(HTableDescriptor, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
 
visitLogEntryBeforeWrite(HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
visitLogEntryBeforeWrite(HTableDescriptor, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
visitLogFiles(FileSystem, Path, FSVisitor.LogFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Iterate over the snapshot log files
visitLogFiles(FileSystem, Path, FSVisitor.LogFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
Iterate over hbase log files
visitRecoveredEdits(FileSystem, Path, FSVisitor.RecoveredEditsVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Iterate over the snapshot recovered.edits
visitReferencedFiles(FileSystem, Path, SnapshotReferenceUtil.FileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Iterate over the snapshot store files, restored.edits and logs
visitRegionRecoveredEdits(FileSystem, Path, FSVisitor.RecoveredEditsVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
Iterate over recovered.edits of the specified region
visitRegionStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Iterate over the snapshot store files in the specified region
visitRegionStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
Iterate over the region store files
visitTableRecoveredEdits(FileSystem, Path, FSVisitor.RecoveredEditsVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
Iterate over each region in the table and inform about recovered.edits
visitTableStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Iterate over the snapshot store files
visitTableStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
Iterate over the table store files

W

W - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'W'
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
 
waitForAssignment(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Waits until the specified region has completed assignment.
waitForAssignment(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
Waits until the specified region has completed assignment.
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.
waitForFlushesAndCompactions() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
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.
waitForMeta(long) - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
Gets the current location for .META. if available and waits for up to the specified timeout if not immediately available.
waitForMeta() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
Waits indefinitely for availability of .META..
waitForMetaServerConnection(long) - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
Deprecated. Use #getMetaServerConnection(long)
waitForProxy(RpcClientEngine, Class<T>, InetSocketAddress, Configuration, int, int, long) - Static method in class org.apache.hadoop.hbase.ipc.HBaseClientRPC
 
waitForRead(MultiVersionConsistencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
Wait for the global readPoint to advance upto the specified transaction number.
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.
waitForUpdate(long) - Method in class org.apache.hadoop.hbase.master.RegionStates
Wait for the state map to be updated by assignment manager.
waitForWork() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
 
waitingTimeForEvents - Variable in class org.apache.hadoop.hbase.executor.EventHandler
 
waitMetaRegionLocation(long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaRegionTracker
Gets the meta region location, if available, and waits for up to the specified timeout if not immediately available.
waitOnMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Wait for the specified master to stop Removes this thread from list of running threads.
waitOnMaster(JVMClusterUtil.MasterThread) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Wait for the specified master to stop Removes this thread from list of running threads.
waitOnRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Wait for the specified region server to stop Removes this thread from list of running threads.
waitOnRegionServer(JVMClusterUtil.RegionServerThread) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
Wait for the specified region server to stop Removes this thread from list of running threads.
waitOnRegionToClearRegionsInTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
Wait on region to clear regions-in-transition.
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.
waitToBecomeLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated. Blocks until this instance has claimed the leader ZNode in ZooKeeper
waitUntilAssigned(HBaseAdmin, 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
 
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_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
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 (HLog)
WALActionsListener - Interface in org.apache.hadoop.hbase.regionserver.wal
Get notification of FSHLog/WAL log events.
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 FSHLog.
WALCoprocessorHost(FSHLog, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
Constructor
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
 
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
 
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.zookeeper.ZooKeeperListener
 
webuiport - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
WEBUIPORT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
WEEK_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
Seconds in a week
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
A wrapper filter that returns true from WhileMatchFilter.filterAllRemaining() as soon as the wrapped filters Filter.filterRowKey(byte[], int, int), Filter.filterKeyValue(org.apache.hadoop.hbase.KeyValue), Filter.filterRow() or Filter.filterAllRemaining() methods returns true.
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) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.BlockingInterface
 
whoami(RpcController, AuthenticationProtos.WhoAmIRequest, RpcCallback<AuthenticationProtos.WhoAmIResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.Interface
 
whoami(RpcController, AuthenticationProtos.WhoAmIRequest, RpcCallback<AuthenticationProtos.WhoAmIResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.Stub
 
whoami(RpcController, AuthenticationProtos.WhoAmIRequest, RpcCallback<AuthenticationProtos.WhoAmIResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
 
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
 
withBlockSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
withBloomType(BloomType) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
withBytesPerChecksum(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
withBytesPerChecksum(int) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
withChecksumType(ChecksumType) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
withChecksumType(ChecksumType) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
withComparator(KeyValue.KeyComparator) - 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.HFile.WriterFactory
 
withCompression(String) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
withCompression(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
withDataBlockEncoder(HFileDataBlockEncoder) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
withDataBlockEncoder(HFileDataBlockEncoder) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
 
withFilePath(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
Use either this method or StoreFile.WriterBuilder.withOutputDir(org.apache.hadoop.fs.Path), but not both.
withinOrAfterTimeRange(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
Check if the specified timestamp is within 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
Use either this method or StoreFile.WriterBuilder.withFilePath(org.apache.hadoop.fs.Path), but not both.
withOutputStream(FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
withoutRetries() - Method in class org.apache.hadoop.hbase.client.ServerCallable
Run this instance against the server once.
withPath(FileSystem, Path) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
withRetries() - Method in class org.apache.hadoop.hbase.client.ServerCallable
Run this instance with retries, timed waits, and refinds of missing regions.
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
 
wrapException(InetSocketAddress, IOException) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
Take an IOException and the address we were trying to connect to and return an IOException with the input exception as the cause.
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.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.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(int) - Method in class org.apache.hadoop.hbase.io.DoubleOutputStream
 
write(byte[]) - Method in class org.apache.hadoop.hbase.io.DoubleOutputStream
 
write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.DoubleOutputStream
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
 
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
Deprecated.  
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
Deprecated.  
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.TableSplit
Writes the field values to the output.
write(DataOutput) - Method in class org.apache.hadoop.hbase.master.RegionState
Deprecated. Writables are going away
write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog.Entry
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
 
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(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(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 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.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.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.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.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.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.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 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.TScan
 
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.ByteRangeTool
 
write(OutputStream, ByteRange, int) - Static method in class org.apache.hadoop.hbase.util.ByteRangeTool
 
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.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.get_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.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.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_LOCK_CHILD_NODE_PREFIX - Static variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
ZNode prefix used by processes acquiring writer locks
WRITE_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
WRITE_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
WRITE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
 
writeBlock(HFileBlock.BlockWritable, FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
Takes the given HFileBlock.BlockWritable instance, creates a new block of its appropriate type, writes the writable into this block, and flushes the block into the output stream.
writeBloom(DataOutput) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
Writes just the bloom filter to the output 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
 
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.
writeHeaderAndData(FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
Similar to HFileBlock.Writer.writeHeaderAndData(FSDataOutputStream), but records the offset of this block so that it can be referenced in the next block of the same type.
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
 
writeLock(byte[]) - Method in interface org.apache.hadoop.hbase.InterProcessReadWriteLock
Obtain a writer lock containing given metadata.
writeLock(byte[], String) - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
 
writeLock(byte[], 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 writer lock containing given metadata.
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.
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
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
 
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.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.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
 
writeReplicationStatus(String, String, long) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
Set the current position of the specified cluster in the current hlog
writeRequest(HBaseClient.Call) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
Initiates a call by sending the parameter to the remote server.
WRITEREQUESTSCOUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
WRITEREQUESTSCOUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
 
writeRowToken(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
UVInt: tokenWidth bytes: token
writeSingleLevelIndex(DataOutput, String) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Writes the block index data as a single level only.
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.
WRITETIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.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(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionsResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions.UserPermissions
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserTablePermissions
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UUID
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit.FamilyScope
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALEdit
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.WALKey
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateArgument
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionResult
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiAction
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiGetResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Cell
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Filter
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.KeyValue
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionLoad
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerLoad
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AddColumnResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.AssignRegionResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.BalanceResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CatalogScanResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.CreateTableResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteColumnResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteSnapshotResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DeleteTableResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DisableTableResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.DispatchMergingRegionsResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableCatalogJanitorResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.EnableTableResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsCatalogJanitorEnabledResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsRestoreSnapshotDoneResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.IsSnapshotDoneResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ListSnapshotResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyColumnResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ModifyTableResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.MoveRegionResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.OfflineRegionResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.RestoreSnapshotResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.SetBalancerRunningResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.ShutdownResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.StopMasterResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.TakeSnapshotResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterAdminProtos.UnassignRegionResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetClusterStatusResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetTableDescriptorsResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutation.MultiMutateResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProcessorProtos.MultiRowMutationProcessorResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorResult
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenProto
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.Tracing.RPCTInfo
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RootRegionServer
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
 
writeTo(CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
 
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.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
 
writeToBlock(DataOutput) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockWritable
Writes the block to the provided stream.
writeToStream(OutputStream) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
 
writeToWAL - Variable in class org.apache.hadoop.hbase.client.Mutation
 
writeToWal - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
writeToWal - Variable in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
writeToWal - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
WRITETOWAL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
 
writeToZooKeeper(byte[], TableAuthManager.PermissionCache<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
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
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
 
WrongRegionException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when a request contains a key which is not part of this region
WrongRegionException() - Constructor for exception org.apache.hadoop.hbase.exceptions.WrongRegionException
constructor
WrongRegionException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.WrongRegionException
Constructor
WrongRowIOException - Exception in org.apache.hadoop.hbase.client
 
WrongRowIOException(String) - Constructor for exception org.apache.hadoop.hbase.client.WrongRowIOException
 

X

XOR_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
 

Y

YETTOUPDATEREGIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterMonitorProtos.GetSchemaAlterStatusResponse
 
YouAreDeadException - Exception in org.apache.hadoop.hbase.exceptions
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.exceptions.YouAreDeadException
 

Z

ZERO - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for Zero
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
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_jsp - Class in org.apache.hadoop.hbase.generated.master
 
zk_jsp() - Constructor for class org.apache.hadoop.hbase.generated.master.zk_jsp
 
ZK_SESSION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for ZooKeeper session timeout
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
 
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() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKConfig
 
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.  
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
ZooKeeper based ProcedureCoordinatorRpcs for a ProcedureCoordinator
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, String) - Constructor for class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
Must call ZKProcedureMemberRpcs.start(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, String) - Constructor for class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
Top-level watcher/controller for procedures across the cluster.
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
 
ZKTable - Class in org.apache.hadoop.hbase.zookeeper
Helper class for table state tracking for use by AssignmentManager.
ZKTable(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKTable
 
ZKTableArchiveClient - Class in org.apache.hadoop.hbase.backup.example
Example class for how to use the table archiving coordinated via zookeeper
ZKTableArchiveClient(Configuration, HConnection) - Constructor for class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
 
ZKTableReadOnly - Class in org.apache.hadoop.hbase.zookeeper
Non-instantiable class that provides helper functions for clients other than AssignmentManager for reading the state of a table in ZK.
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
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_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_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
ZooKeeperConnectionException - Exception in org.apache.hadoop.hbase.exceptions
Thrown if the client can't connect to zookeeper
ZooKeeperConnectionException() - Constructor for exception org.apache.hadoop.hbase.exceptions.ZooKeeperConnectionException
default constructor
ZooKeeperConnectionException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ZooKeeperConnectionException
Constructor
ZooKeeperConnectionException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.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.
ZooKeeperMainServerArg - Class in org.apache.hadoop.hbase.zookeeper
Tool for reading a ZooKeeper server from HBase XML configuration producing the '-server host:port' argument to pass ZooKeeperMain.
ZooKeeperMainServerArg() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZooKeeperMainServerArg
 
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.
ZooKeeperProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ClusterUp - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ClusterUp.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ClusterUpOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.Master - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.Master.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.MasterOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.RegionTransition - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.RegionTransition.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.RegionTransitionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ReplicationHLogPosition - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ReplicationHLogPosition.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ReplicationHLogPositionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ReplicationLock - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ReplicationLock.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ReplicationLockOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ReplicationPeer - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ReplicationPeer.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ReplicationPeerOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ReplicationState - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ReplicationState.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ReplicationState.State - Enum in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.ReplicationStateOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.RootRegionServer - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.RootRegionServer.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.RootRegionServerOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.SplitLogTask - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.SplitLogTask.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.SplitLogTask.State - Enum in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.SplitLogTaskOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.Table - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.Table.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.Table.State - Enum in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.TableLock - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.TableLock.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.TableLockOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
ZooKeeperProtos.TableOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
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(BackupMasterListTmpl.ImplData) - Static method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterListTmplImpl
 
__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(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.master.master_jsp
 
_jspService(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.generated.master.snapshot_jsp
 
_jspService(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.generated.master.table_jsp
 
_jspService(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.generated.master.tablesDetailed_jsp
 
_jspService(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.generated.master.zk_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.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 X Y Z _

Copyright © 2013 The Apache Software Foundation. All Rights Reserved.