Skip navigation links
Hortonworks Data Platform 2.4.0
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 _ 

H

H - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'H'
hadDelete() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
HadoopSecurityEnabledUserProviderForTesting - Class in org.apache.hadoop.hbase.mapreduce
A UserProvider that always says hadoop security is enabled, regardless of the underlying configuration.
HadoopSecurityEnabledUserProviderForTesting() - Constructor for class org.apache.hadoop.hbase.mapreduce.HadoopSecurityEnabledUserProviderForTesting
 
HadoopShims - Interface in org.apache.hadoop.hbase
A compatibility shim layer for interacting with different versions of Hadoop.
HadoopShimsImpl - Class in org.apache.hadoop.hbase
Compatibility shim layer implementation for Hadoop-2.
HadoopShimsImpl() - Constructor for class org.apache.hadoop.hbase.HadoopShimsImpl
 
hadPostAppend() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPostBatchMutate() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPostBatchMutateIndispensably() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPostBulkLoadHFile() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPostCheckAndDelete() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPostCheckAndPut() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPostCloseRegionOperation() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPostGet() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPostIncrement() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPostPut() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPostStartRegionOperation() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPostWALRestore() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPreAppend() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPreAppendAfterRowLock() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPreBatchMutate() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPreBulkLoadHFile() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPreCheckAndDelete() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPreCheckAndDeleteAfterRowLock() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPreCheckAndPut() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPreCheckAndPutAfterRowLock() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPreGet() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPreIncrement() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPreIncrementAfterRowLock() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPrePreparedDeleteTS() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPrePut() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
hadPreWALRestore() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
 
HalfStoreFileReader - Class in org.apache.hadoop.hbase.io
A facade for a HFile.Reader that serves up either the top or bottom half of a HFile where 'bottom' is the first half of the file containing the keys that sort lowest and 'top' is the second half of the file with keys that sort greater than those of the bottom half.
HalfStoreFileReader(FileSystem, Path, CacheConfig, Reference, Configuration) - Constructor for class org.apache.hadoop.hbase.io.HalfStoreFileReader
Creates a half file reader for a normal hfile.
HalfStoreFileReader(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, Configuration) - Constructor for class org.apache.hadoop.hbase.io.HalfStoreFileReader
Creates a half file reader for a hfile referred to by an hfilelink.
hammerEviction(BlockCache, int, int, int) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheTestUtils
 
hammerSingleKey(BlockCache, int, int, int) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheTestUtils
 
handle(Callback[]) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslDigestCallbackHandler
handle(Callback[]) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslGssCallbackHandler
handle(int, Random, Throwable) - Method in interface org.apache.hadoop.hbase.security.SaslClientHandler.SaslExceptionHandler
Handle the exception
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, TableName) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
Create the on-disk structure for the table, and returns the regions info.
handleCreateHdfsRegions(Path, TableName) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
Create the on-disk regions, using the tableRootDir provided by the CreateTableHandler.
handleDegenerateRegion(HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling a region that has the same start and end key.
handleDegenerateRegion(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling a region that has the same start and end key.
handleDuplicateStartKeys(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling two regions that have the same start key.
handleDuplicateStartKeys(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling two regions that have the same start key.
handleException(Throwable) - Method in class org.apache.hadoop.hbase.executor.EventHandler
Event exception handler, may be overridden
handleException(Throwable) - Method in class org.apache.hadoop.hbase.master.handler.MetaServerShutdownHandler
 
handleException(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
 
handleHoleInRegionChain(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling a region hole between two keys.
handleHoleInRegionChain(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling a region hole between two keys.
handleLockMetadata(String) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Process metadata stored in a ZNode using a callback
handleLockMetadata(String, InterProcessLock.MetadataHandler) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
Process metadata stored in a ZNode using a callback object passed to this instance.
handleMetadata(byte[]) - Method in interface org.apache.hadoop.hbase.InterProcessLock.MetadataHandler
Called after lock metadata is successfully read from a distributed lock service.
handleOverlapGroup(Collection<HBaseFsck.HbckInfo>) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling an group of regions that overlap.
handleOverlapGroup(Collection<HBaseFsck.HbckInfo>) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling an group of regions that overlap.
handleOverlapInRegionChain(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling two reigons that overlap in some arbitrary way.
handleOverlapInRegionChain(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling two reigons that overlap in some arbitrary way.
handler - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
 
handlerAdded(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.SaslClientHandler
 
handleRegionEndKeyNotEmpty(byte[]) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling case where a Table has a last region that does not have an empty end key.
handleRegionEndKeyNotEmpty(byte[]) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling case where a Table has a last region that does not have an empty end key.
handleRegionStartKeyNotEmpty(HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
Callback for handling case where a Table has a first region that does not have an empty start key.
handleRegionStartKeyNotEmpty(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Callback for handling case where a Table has a first region that does not have an empty start key.
handleReportForDutyResponse(RegionServerStatusProtos.RegionServerStartupResponse) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster.MiniHBaseClusterRegionServer
 
handleReportForDutyResponse(RegionServerStatusProtos.RegionServerStartupResponse) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
handleReportForDutyResponse(RegionServerStatusProtos.RegionServerStartupResponse) - Method in class org.apache.hadoop.hbase.regionserver.TestRSKilledWhenInitializing.MockedRegionServer
 
handleRowModel(TestTableScan.ClientSideCellSetModel, RowModel) - Method in interface org.apache.hadoop.hbase.rest.TestTableScan.ClientSideCellSetModel.Listener
 
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.handler.TruncateTableHandler
 
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.
HAS_COMPRESSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
 
HAS_TAG_COMPRESSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
 
hasAccess(User, TableName, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
 
hasAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
required .FlushDescriptor.FlushAction action = 1;
hasAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
required .FlushDescriptor.FlushAction action = 1;
hasAction() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
required .FlushDescriptor.FlushAction action = 1;
hasAdministratorAccess(ServletContext, HttpServletRequest, HttpServletResponse) - Static method in class org.apache.hadoop.hbase.http.HttpServer
Does the user sending the HttpServletRequest has the administrator ACLs? If it isn't the case, response will be modified to send an error to the user.
hasAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
required uint64 ageOfLastAppliedOp = 1;
hasAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
required uint64 ageOfLastAppliedOp = 1;
hasAgeOfLastAppliedOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSinkOrBuilder
required uint64 ageOfLastAppliedOp = 1;
hasAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
required uint64 ageOfLastShippedOp = 2;
hasAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
required uint64 ageOfLastShippedOp = 2;
hasAgeOfLastShippedOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
required uint64 ageOfLastShippedOp = 2;
hasAlgorithm() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
required string algorithm = 1;
hasAlgorithm() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
required string algorithm = 1;
hasAlgorithm() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
required string algorithm = 1;
hasAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
optional bool assign_seq_num = 3;
hasAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
optional bool assign_seq_num = 3;
hasAssignSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
optional bool assign_seq_num = 3;
hasAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
optional bool assign_seq_num = 2;
hasAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
optional bool assign_seq_num = 2;
hasAssignSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
optional bool assign_seq_num = 2;
hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
optional int32 associated_cell_count = 3;
hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
optional int32 associated_cell_count = 3;
hasAssociatedCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
optional int32 associated_cell_count = 3;
hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
optional int32 associated_cell_count = 8;
hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
optional int32 associated_cell_count = 8;
hasAssociatedCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
optional int32 associated_cell_count = 8;
hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
optional int32 associated_cell_count = 2;
hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
optional int32 associated_cell_count = 2;
hasAssociatedCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
optional int32 associated_cell_count = 2;
hasAtomic() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
optional bool atomic = 2;
hasAtomic() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
optional bool atomic = 2;
hasAtomic() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionOrBuilder
optional bool atomic = 2;
hasAttributes() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
hasAuthMethod() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
optional string auth_method = 2;
hasAuthMethod() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
optional string auth_method = 2;
hasAuthMethod() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponseOrBuilder
optional string auth_method = 2;
hasAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional double averageLoad = 5;
hasAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
optional double averageLoad = 5;
hasAverageLoad() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
optional double averageLoad = 5;
hasBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
optional bool balancer_on = 9;
hasBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
optional bool balancer_on = 9;
hasBalancerOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
optional bool balancer_on = 9;
hasBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
optional bool balancer_on = 1;
hasBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
optional bool balancer_on = 1;
hasBalancerOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerStateOrBuilder
optional bool balancer_on = 1;
hasBalancerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
required bool balancer_ran = 1;
hasBalancerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
required bool balancer_ran = 1;
hasBalancerRan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponseOrBuilder
required bool balancer_ran = 1;
hasBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 batch = 4;
hasBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int32 batch = 4;
hasBatch() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int32 batch = 4;
hasBatchSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional uint32 batch_size = 9;
hasBatchSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional uint32 batch_size = 9;
hasBatchSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional uint32 batch_size = 9;
hasBigdecimalMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
required bytes bigdecimal_msg = 1;
hasBigdecimalMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
required bytes bigdecimal_msg = 1;
hasBigdecimalMsg() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsgOrBuilder
required bytes bigdecimal_msg = 1;
hasBitwiseOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
required .BitComparator.BitwiseOp bitwise_op = 2;
hasBitwiseOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
required .BitComparator.BitwiseOp bitwise_op = 2;
hasBitwiseOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparatorOrBuilder
required .BitComparator.BitwiseOp bitwise_op = 2;
hasBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
 
hasBulkloadSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
required int64 bulkload_seq_num = 4;
hasBulkloadSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
required int64 bulkload_seq_num = 4;
hasBulkloadSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
required int64 bulkload_seq_num = 4;
hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
required string bulk_token = 1;
hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
required string bulk_token = 1;
hasBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequestOrBuilder
required string bulk_token = 1;
hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
required string bulk_token = 1;
hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
required string bulk_token = 1;
hasBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponseOrBuilder
required string bulk_token = 1;
hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
required string bulk_token = 4;
hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
required string bulk_token = 4;
hasBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
required string bulk_token = 4;
hasBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
optional bool bypass_globals = 6;
hasBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
optional bool bypass_globals = 6;
hasBypassGlobals() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
optional bool bypass_globals = 6;
hasBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
optional bool bypass_globals = 1 [default = false];
hasBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
optional bool bypass_globals = 1 [default = false];
hasBypassGlobals() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotasOrBuilder
optional bool bypass_globals = 1 [default = false];
hasBypassGlobals() - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
 
hasCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
optional bool cache_blocks = 7 [default = true];
hasCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
optional bool cache_blocks = 7 [default = true];
hasCacheBlocks() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
optional bool cache_blocks = 7 [default = true];
hasCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional bool cache_blocks = 8 [default = true];
hasCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional bool cache_blocks = 8 [default = true];
hasCacheBlocks() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional bool cache_blocks = 8 [default = true];
hasCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bool cacheBlocks = 11;
hasCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional bool cacheBlocks = 11;
hasCacheBlocks() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional bool cacheBlocks = 11;
hasCaching() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional uint32 caching = 17;
hasCaching() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional uint32 caching = 17;
hasCaching() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional uint32 caching = 17;
hasCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 caching = 9;
hasCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int32 caching = 9;
hasCaching() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int32 caching = 9;
hasCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
required .CoprocessorServiceCall call = 2;
hasCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
required .CoprocessorServiceCall call = 2;
hasCall() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
required .CoprocessorServiceCall call = 2;
hasCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
optional uint32 call_id = 1;
hasCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
optional uint32 call_id = 1;
hasCallId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
optional uint32 call_id = 1;
hasCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
optional uint32 call_id = 1;
hasCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
optional uint32 call_id = 1;
hasCallId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
optional uint32 call_id = 1;
hasCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
 
hasCellBlockCodecClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
optional string cell_block_codec_class = 3;
hasCellBlockCodecClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
optional string cell_block_codec_class = 3;
hasCellBlockCodecClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
optional string cell_block_codec_class = 3;
hasCellBlockCompressorClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
optional string cell_block_compressor_class = 4;
hasCellBlockCompressorClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
optional string cell_block_compressor_class = 4;
hasCellBlockCompressorClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
optional string cell_block_compressor_class = 4;
hasCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
optional .CellBlockMeta cell_block_meta = 5;
hasCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
optional .CellBlockMeta cell_block_meta = 5;
hasCellBlockMeta() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
optional .CellBlockMeta cell_block_meta = 5;
hasCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
optional .CellBlockMeta cell_block_meta = 3;
hasCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
optional .CellBlockMeta cell_block_meta = 3;
hasCellBlockMeta() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
optional .CellBlockMeta cell_block_meta = 3;
hasCellCodecClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
optional string cell_codec_cls_name = 5;
hasCellCodecClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
optional string cell_codec_cls_name = 5;
hasCellCodecClsName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
optional string cell_codec_cls_name = 5;
hasCellTTL() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
hasCellType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
optional .CellType cell_type = 5;
hasCellType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
optional .CellType cell_type = 5;
hasCellType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
optional .CellType cell_type = 5;
hasCellVisibility() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
hasChance() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
required float chance = 1;
hasChance() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
required float chance = 1;
hasChance() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilterOrBuilder
required float chance = 1;
hasCharset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
required string charset = 3;
hasCharset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
required string charset = 3;
hasCharset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
required string charset = 3;
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
optional string class_name = 1;
hasClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
optional string class_name = 1;
hasClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
optional string class_name = 1;
hasClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
required string class_name = 1;
hasClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
required string class_name = 1;
hasClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
required string class_name = 1;
hasClientAckTime() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
hasClientHandlesHeartbeats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
optional bool client_handles_heartbeats = 8;
hasClientHandlesHeartbeats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
optional bool client_handles_heartbeats = 8;
hasClientHandlesHeartbeats() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
optional bool client_handles_heartbeats = 8;
hasClientHandlesPartials() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
optional bool client_handles_partials = 7;
hasClientHandlesPartials() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
optional bool client_handles_partials = 7;
hasClientHandlesPartials() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
optional bool client_handles_partials = 7;
hasClosed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
required bool closed = 1;
hasClosed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
required bool closed = 1;
hasClosed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponseOrBuilder
required bool closed = 1;
hasCloseScanner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
optional bool close_scanner = 5;
hasCloseScanner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
optional bool close_scanner = 5;
hasCloseScanner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
optional bool close_scanner = 5;
hasClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
optional bool closest_row_before = 11 [default = false];
hasClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
optional bool closest_row_before = 11 [default = false];
hasClosestRowBefore() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
optional bool closest_row_before = 11 [default = false];
hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
required string cluster_id = 1;
hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
required string cluster_id = 1;
hasClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterIdOrBuilder
required string cluster_id = 1;
hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
optional .ClusterId cluster_id = 5;
hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
optional .ClusterId cluster_id = 5;
hasClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
optional .ClusterId cluster_id = 5;
hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
Deprecated.
hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
Deprecated.
hasClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
Deprecated.
hasClusterkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
required string clusterkey = 1;
hasClusterkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
required string clusterkey = 1;
hasClusterkey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
required string clusterkey = 1;
hasClusterStatus() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
required .ClusterStatus cluster_status = 1;
hasClusterStatus() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
required .ClusterStatus cluster_status = 1;
hasClusterStatus() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponseOrBuilder
required .ClusterStatus cluster_status = 1;
hasColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes column = 2;
hasColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
optional bytes column = 2;
hasColumn() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
optional bytes column = 2;
hasColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
required .ColumnFamilySchema column_families = 2;
hasColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
required .ColumnFamilySchema column_families = 2;
hasColumnFamilies() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequestOrBuilder
required .ColumnFamilySchema column_families = 2;
hasColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
required .ColumnFamilySchema column_families = 2;
hasColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
required .ColumnFamilySchema column_families = 2;
hasColumnFamilies() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequestOrBuilder
required .ColumnFamilySchema column_families = 2;
hasColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
optional bytes column_family = 2;
hasColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
optional bytes column_family = 2;
hasColumnFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
optional bytes column_family = 2;
hasColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
optional bytes column_family = 1;
hasColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
optional bytes column_family = 1;
hasColumnFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
optional bytes column_family = 1;
hasColumnfamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
required bytes columnfamily_name = 3;
hasColumnfamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
required bytes columnfamily_name = 3;
hasColumnfamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
required bytes columnfamily_name = 3;
hasColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
required .ColumnFamilySchema columnfamily_schema = 3;
hasColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
required .ColumnFamilySchema columnfamily_schema = 3;
hasColumnfamilySchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
required .ColumnFamilySchema columnfamily_schema = 3;
hasColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
required .ColumnFamilySchema columnfamily_schema = 3;
hasColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
required .ColumnFamilySchema columnfamily_schema = 3;
hasColumnfamilySchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
required .ColumnFamilySchema columnfamily_schema = 3;
hasColumnName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
required bytes column_name = 2;
hasColumnName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
required bytes column_name = 2;
hasColumnName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequestOrBuilder
required bytes column_name = 2;
hasColumnOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
optional bytes column_offset = 3;
hasColumnOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
optional bytes column_offset = 3;
hasColumnOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilterOrBuilder
optional bytes column_offset = 3;
hasColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
optional bytes column_qualifier = 3;
hasColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
optional bytes column_qualifier = 3;
hasColumnQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
optional bytes column_qualifier = 3;
hasColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
optional bytes column_qualifier = 2;
hasColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
optional bytes column_qualifier = 2;
hasColumnQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
optional bytes column_qualifier = 2;
hasColumns() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
hasCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
optional bool compaction_state = 2;
hasCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
optional bool compaction_state = 2;
hasCompactionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequestOrBuilder
optional bool compaction_state = 2;
hasCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
optional .GetRegionInfoResponse.CompactionState compaction_state = 2;
hasCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
optional .GetRegionInfoResponse.CompactionState compaction_state = 2;
hasCompactionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
optional .GetRegionInfoResponse.CompactionState compaction_state = 2;
hasCompactionTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
required int64 compaction_timestamp = 1;
hasCompactionTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
required int64 compaction_timestamp = 1;
hasCompactionTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponseOrBuilder
required int64 compaction_timestamp = 1;
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
required .ByteArrayComparable comparable = 1;
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
required .ByteArrayComparable comparable = 1;
hasComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparatorOrBuilder
required .ByteArrayComparable comparable = 1;
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
required .ByteArrayComparable comparable = 1;
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
required .ByteArrayComparable comparable = 1;
hasComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparatorOrBuilder
required .ByteArrayComparable comparable = 1;
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
required .ByteArrayComparable comparable = 1;
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
required .ByteArrayComparable comparable = 1;
hasComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparatorOrBuilder
required .ByteArrayComparable comparable = 1;
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
required .ByteArrayComparable comparable = 1;
hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
required .ByteArrayComparable comparable = 1;
hasComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparatorOrBuilder
required .ByteArrayComparable comparable = 1;
hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
required .Comparator comparator = 5;
hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
required .Comparator comparator = 5;
hasComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
required .Comparator comparator = 5;
hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
optional .Comparator comparator = 2;
hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
optional .Comparator comparator = 2;
hasComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilterOrBuilder
optional .Comparator comparator = 2;
hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
required .Comparator comparator = 4;
hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
required .Comparator comparator = 4;
hasComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
required .Comparator comparator = 4;
hasComparatorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
optional string comparator_class_name = 11;
hasComparatorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
optional string comparator_class_name = 11;
hasComparatorClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
optional string comparator_class_name = 11;
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilterOrBuilder
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilterOrBuilder
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilterOrBuilder
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
required .CompareFilter compare_filter = 1;
hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilterOrBuilder
required .CompareFilter compare_filter = 1;
hasCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
required .CompareType compare_op = 1;
hasCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
required .CompareType compare_op = 1;
hasCompareOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilterOrBuilder
required .CompareType compare_op = 1;
hasCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
required .CompareType compare_op = 3;
hasCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
required .CompareType compare_op = 3;
hasCompareOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
required .CompareType compare_op = 3;
hasCompareType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
required .CompareType compare_type = 4;
hasCompareType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
required .CompareType compare_type = 4;
hasCompareType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
required .CompareType compare_type = 4;
hasCompleteSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint64 complete_sequence_id = 15;
hasCompleteSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint64 complete_sequence_id = 15;
hasCompleteSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint64 complete_sequence_id = 15;
hasCompression - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
hasCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
hasCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
hasCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
hasCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string compression = 5;
hasCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional string compression = 5;
hasCompression() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional string compression = 5;
hasCompressionCodec() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
optional uint32 compression_codec = 12;
hasCompressionCodec() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
optional uint32 compression_codec = 12;
hasCompressionCodec() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
optional uint32 compression_codec = 12;
hasCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
optional .Condition condition = 3;
hasCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
optional .Condition condition = 3;
hasCondition() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
optional .Condition condition = 3;
hasCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
optional .Condition condition = 3;
hasCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
optional .Condition condition = 3;
hasCondition() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
optional .Condition condition = 3;
hasConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
optional .Consistency consistency = 12 [default = STRONG];
hasConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
optional .Consistency consistency = 12 [default = STRONG];
hasConsistency() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
optional .Consistency consistency = 12 [default = STRONG];
hasConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional .Consistency consistency = 16 [default = STRONG];
hasConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional .Consistency consistency = 16 [default = STRONG];
hasConsistency() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional .Consistency consistency = 16 [default = STRONG];
hasCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Check if the table has an attached co-processor represented by the name className
hasCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
required int64 count = 1 [default = 0];
hasCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
required int64 count = 1 [default = 0];
hasCount() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponseOrBuilder
required int64 count = 1 [default = 0];
hasCount() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse.Builder
required int32 count = 1;
hasCount() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse
required int32 count = 1;
hasCount() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponseOrBuilder
required int32 count = 1;
hasCount() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse.Builder
required int32 count = 1;
hasCount() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse
required int32 count = 1;
hasCount() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponseOrBuilder
required int32 count = 1;
hasCounter() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest.Builder
required int32 counter = 2;
hasCounter() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest
required int32 counter = 2;
hasCounter() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequestOrBuilder
required int32 counter = 2;
hasCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
required uint64 create_time = 3;
hasCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
required uint64 create_time = 3;
hasCreateTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
required uint64 create_time = 3;
hasCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
optional int64 create_time = 6;
hasCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
optional int64 create_time = 6;
hasCreateTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
optional int64 create_time = 6;
hasCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
optional int64 creation_time = 3 [default = 0];
hasCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
optional int64 creation_time = 3 [default = 0];
hasCreationTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
optional int64 creation_time = 3 [default = 0];
hasCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
optional int64 creation_time = 3 [default = 0];
hasCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
optional int64 creation_time = 3 [default = 0];
hasCreationTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
optional int64 creation_time = 3 [default = 0];
hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint64 current_compacted_KVs = 11;
hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint64 current_compacted_KVs = 11;
hasCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint64 current_compacted_KVs = 11;
hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 currentCompactedKVs = 13;
hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int64 currentCompactedKVs = 13;
hasCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int64 currentCompactedKVs = 13;
hasData() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
required bytes data = 3;
hasData() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
required bytes data = 3;
hasData() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
required bytes data = 3;
hasData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes data = 4;
hasData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
optional bytes data = 4;
hasData() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
optional bytes data = 4;
hasDataIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
optional uint32 data_index_count = 5;
hasDataIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
optional uint32 data_index_count = 5;
hasDataIndexCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
optional uint32 data_index_count = 5;
hasDataLocality() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional float data_locality = 16;
hasDataLocality() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional float data_locality = 16;
hasDataLocality() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional float data_locality = 16;
hasDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
required string date = 5;
hasDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
required string date = 5;
hasDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
required string date = 5;
hasDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
optional string declaring_class = 1;
hasDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
optional string declaring_class = 1;
hasDeclaringClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
optional string declaring_class = 1;
hasDelay() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg.Builder
required bool delay = 1;
hasDelay() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg
required bool delay = 1;
hasDelay() - Method in interface org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArgOrBuilder
required bool delay = 1;
hasDeleteColumnFamilyInModify() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
required bool delete_column_family_in_modify = 4;
hasDeleteColumnFamilyInModify() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
required bool delete_column_family_in_modify = 4;
hasDeleteColumnFamilyInModify() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
required bool delete_column_family_in_modify = 4;
hasDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .BulkDeleteRequest.DeleteType deleteType = 2;
hasDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
required .BulkDeleteRequest.DeleteType deleteType = 2;
hasDeleteType() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
required .BulkDeleteRequest.DeleteType deleteType = 2;
hasDeleteType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
optional .MutationProto.DeleteType delete_type = 4;
hasDeleteType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
optional .MutationProto.DeleteType delete_type = 4;
hasDeleteType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
optional .MutationProto.DeleteType delete_type = 4;
hasDestinationServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
optional .ServerName destination_server = 4;
hasDestinationServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
optional .ServerName destination_server = 4;
hasDestinationServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
optional .ServerName destination_server = 4;
hasDestServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
optional .ServerName dest_server_name = 2;
hasDestServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
optional .ServerName dest_server_name = 2;
hasDestServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequestOrBuilder
optional .ServerName dest_server_name = 2;
hasDiff() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest.Builder
required int32 diff = 1;
hasDiff() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest
required int32 diff = 1;
hasDiff() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequestOrBuilder
required int32 diff = 1;
hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
optional bool done = 1 [default = false];
hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
optional bool done = 1 [default = false];
hasDone() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponseOrBuilder
optional bool done = 1 [default = false];
hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
optional bool done = 1 [default = false];
hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
optional bool done = 1 [default = false];
hasDone() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponseOrBuilder
optional bool done = 1 [default = false];
hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
optional bool done = 1 [default = false];
hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
optional bool done = 1 [default = false];
hasDone() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponseOrBuilder
optional bool done = 1 [default = false];
hasDoNotRetry() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
optional bool do_not_retry = 5;
hasDoNotRetry() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
optional bool do_not_retry = 5;
hasDoNotRetry() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
optional bool do_not_retry = 5;
hasDoubleMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
required double double_msg = 1;
hasDoubleMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
required double double_msg = 1;
hasDoubleMsg() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsgOrBuilder
required double double_msg = 1;
hasDropDependentColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
optional bool drop_dependent_column = 4;
hasDropDependentColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
optional bool drop_dependent_column = 4;
hasDropDependentColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
optional bool drop_dependent_column = 4;
hasDurability() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
optional .MutationProto.Durability durability = 6 [default = USE_DEFAULT];
hasDurability() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
optional .MutationProto.Durability durability = 6 [default = USE_DEFAULT];
hasDurability() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
optional .MutationProto.Durability durability = 6 [default = USE_DEFAULT];
hasEffectiveUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
required string effective_user = 1;
hasEffectiveUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
required string effective_user = 1;
hasEffectiveUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformationOrBuilder
required string effective_user = 1;
hasEnable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
required bool enable = 1;
hasEnable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
required bool enable = 1;
hasEnable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequestOrBuilder
required bool enable = 1;
hasEnabled() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
required bool enabled = 1;
hasEnabled() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
required bool enabled = 1;
hasEnabled() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponseOrBuilder
required bool enabled = 1;
hasEnabled() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse.Builder
required bool enabled = 1;
hasEnabled() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse
required bool enabled = 1;
hasEnabled() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponseOrBuilder
required bool enabled = 1;
hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
required bytes encoded_region_name = 2;
hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
required bytes encoded_region_name = 2;
hasEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
required bytes encoded_region_name = 2;
hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
required bytes encoded_region_name = 2;
hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
required bytes encoded_region_name = 2;
hasEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
required bytes encoded_region_name = 2;
hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
required bytes encoded_region_name = 3;
hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
required bytes encoded_region_name = 3;
hasEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
required bytes encoded_region_name = 3;
hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
required bytes encoded_region_name = 3;
hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
required bytes encoded_region_name = 3;
hasEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
required bytes encoded_region_name = 3;
hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
required bytes encoded_region_name = 1;
hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
required bytes encoded_region_name = 1;
hasEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
required bytes encoded_region_name = 1;
hasEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
optional bytes encryption_key = 13;
hasEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
optional bytes encryption_key = 13;
hasEncryptionKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
optional bytes encryption_key = 13;
hasEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
optional bytes encryption_key = 2;
hasEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
optional bytes encryption_key = 2;
hasEncryptionKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
optional bytes encryption_key = 2;
hasEndKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
optional bytes end_key = 4;
hasEndKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
optional bytes end_key = 4;
hasEndKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
optional bytes end_key = 4;
hasEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional bytes endKey = 3;
hasEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
optional bytes endKey = 3;
hasEndKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
optional bytes endKey = 3;
hasEndRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
hasEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bytes endRow = 2;
hasEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional bytes endRow = 2;
hasEndRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional bytes endRow = 2;
hasEndRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
hasEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int64 endTime = 6;
hasEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int64 endTime = 6;
hasEndTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int64 endTime = 6;
hasEngine() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
optional string engine = 4;
hasEngine() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
optional string engine = 4;
hasEngine() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
optional string engine = 4;
hasEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
optional uint64 entry_count = 7;
hasEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
optional uint64 entry_count = 7;
hasEntryCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
optional uint64 entry_count = 7;
hasError() - Method in class org.apache.hadoop.hbase.tool.Canary.Monitor
 
hasErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
optional bytes error_info = 3;
hasErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
optional bytes error_info = 3;
hasErrorInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
optional bytes error_info = 3;
hasErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
optional string error_message = 1;
hasErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
optional string error_message = 1;
hasErrorMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponseOrBuilder
optional string error_message = 1;
hasErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
required string error_message = 2;
hasErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
required string error_message = 2;
hasErrorMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder
required string error_message = 2;
hasEventType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
required .RegionEventDescriptor.EventType event_type = 1;
hasEventType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
required .RegionEventDescriptor.EventType event_type = 1;
hasEventType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
required .RegionEventDescriptor.EventType event_type = 1;
hasEventTypeCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
required uint32 event_type_code = 1;
hasEventTypeCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
required uint32 event_type_code = 1;
hasEventTypeCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
required uint32 event_type_code = 1;
hasException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
 
hasException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
hasException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
hasException() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
optional .NameBytesPair exception = 2;
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
optional .NameBytesPair exception = 2;
hasException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResultOrBuilder
optional .NameBytesPair exception = 2;
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
optional .NameBytesPair exception = 3;
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
optional .NameBytesPair exception = 3;
hasException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
optional .NameBytesPair exception = 3;
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
optional .ForeignExceptionMessage exception = 5;
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
optional .ForeignExceptionMessage exception = 5;
hasException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
optional .ForeignExceptionMessage exception = 5;
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
optional .ForeignExceptionMessage exception = 10;
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
optional .ForeignExceptionMessage exception = 10;
hasException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
optional .ForeignExceptionMessage exception = 10;
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
optional .ExceptionResponse exception = 2;
hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
optional .ExceptionResponse exception = 2;
hasException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
optional .ExceptionResponse exception = 2;
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
optional string exception_class_name = 1;
hasExceptionClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
optional string exception_class_name = 1;
hasExceptionClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
optional string exception_class_name = 1;
hasExecuted() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
required bool executed = 1;
hasExecuted() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
required bool executed = 1;
hasExecuted() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureDataOrBuilder
required bool executed = 1;
hasExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
optional bool existence_only = 10 [default = false];
hasExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
optional bool existence_only = 10 [default = false];
hasExistenceOnly() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
optional bool existence_only = 10 [default = false];
hasExists() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
optional bool exists = 3;
hasExists() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
optional bool exists = 3;
hasExists() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
optional bool exists = 3;
hasExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
optional int64 expected_timeout = 1;
hasExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
optional int64 expected_timeout = 1;
hasExpectedTimeout() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponseOrBuilder
optional int64 expected_timeout = 1;
hasExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
required int64 expected_timeout = 1;
hasExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
required int64 expected_timeout = 1;
hasExpectedTimeout() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponseOrBuilder
required int64 expected_timeout = 1;
hasExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
required int64 expiration_date = 2;
hasExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
required int64 expiration_date = 2;
hasExpirationDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
required int64 expiration_date = 2;
hasExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
optional int64 expiration_date = 5;
hasExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
optional int64 expiration_date = 5;
hasExpirationDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
optional int64 expiration_date = 5;
hasExpression() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
required string expression = 1;
hasExpression() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
required string expression = 1;
hasExpression() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibilityOrBuilder
required string expression = 1;
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() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest.Builder
required bytes family = 1;
hasFamily() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest
required bytes family = 1;
hasFamily() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequestOrBuilder
required bytes family = 1;
hasFamily() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest.Builder
required bytes family = 1;
hasFamily() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest
required bytes family = 1;
hasFamily() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequestOrBuilder
required bytes family = 1;
hasFamily() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest.Builder
required bytes family = 1;
hasFamily() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest
required bytes family = 1;
hasFamily() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequestOrBuilder
required bytes family = 1;
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.TablePermission.Builder
optional bytes family = 2;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
optional bytes family = 2;
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermissionOrBuilder
optional bytes family = 2;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
optional bytes family = 3;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
optional bytes family = 3;
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
optional bytes family = 3;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
optional bytes family = 2;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
optional bytes family = 2;
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
optional bytes family = 2;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
required bytes family = 2;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
required bytes family = 2;
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
required bytes family = 2;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
required bytes family = 1;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
required bytes family = 1;
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPathOrBuilder
required bytes family = 1;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
required bytes family = 1;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
required bytes family = 1;
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ColumnOrBuilder
required bytes family = 1;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
required bytes family = 2;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
required bytes family = 2;
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
required bytes family = 2;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
required bytes family = 1;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
required bytes family = 1;
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
required bytes family = 1;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
required bytes family = 1;
hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
required bytes family = 1;
hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScopeOrBuilder
required bytes family = 1;
hasFamily() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
required bytes family_name = 1;
hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
required bytes family_name = 1;
hasFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceIdOrBuilder
required bytes family_name = 1;
hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
required bytes family_name = 1;
hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
required bytes family_name = 1;
hasFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFilesOrBuilder
required bytes family_name = 1;
hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
required bytes family_name = 3;
hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
required bytes family_name = 3;
hasFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
required bytes family_name = 3;
hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
required bytes family_name = 1;
hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
required bytes family_name = 1;
hasFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptorOrBuilder
required bytes family_name = 1;
hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
required bytes family_name = 1;
hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
required bytes family_name = 1;
hasFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptorOrBuilder
required bytes family_name = 1;
hasFamilyStamp - Variable in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
 
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
optional uint64 file_info_offset = 1;
hasFileInfoOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
optional uint64 file_info_offset = 1;
hasFileInfoOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
optional uint64 file_info_offset = 1;
hasFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
optional string file_name = 3;
hasFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
optional string file_name = 3;
hasFileName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
optional string file_name = 3;
hasFileSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
optional uint64 file_size = 3;
hasFileSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
optional uint64 file_size = 3;
hasFileSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFileOrBuilder
optional uint64 file_size = 3;
hasFilter() - Method in class org.apache.hadoop.hbase.client.Scan
 
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
optional .Filter filter = 4;
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
optional .Filter filter = 4;
hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
optional .Filter filter = 4;
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional .Filter filter = 5;
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional .Filter filter = 5;
hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional .Filter filter = 5;
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
required .Filter filter = 1;
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
required .Filter filter = 1;
hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapperOrBuilder
required .Filter filter = 1;
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
required .Filter filter = 1;
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
required .Filter filter = 1;
hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilterOrBuilder
required .Filter filter = 1;
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
required .Filter filter = 1;
hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
required .Filter filter = 1;
hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilterOrBuilder
required .Filter filter = 1;
hasFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional string filter = 8;
hasFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional string filter = 8;
hasFilter() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional string filter = 8;
hasFilterIfMissing() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
optional bool filter_if_missing = 5;
hasFilterIfMissing() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
optional bool filter_if_missing = 5;
hasFilterIfMissing() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
optional bool filter_if_missing = 5;
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.FilterAllFilter
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterBase
Fitlers that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
 
hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.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
required bytes first = 1;
hasFirst() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
required bytes first = 1;
hasFirst() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPairOrBuilder
required bytes first = 1;
hasFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
optional uint64 first_data_block_offset = 9;
hasFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
optional uint64 first_data_block_offset = 9;
hasFirstDataBlockOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
optional uint64 first_data_block_offset = 9;
hasFlushed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
optional bool flushed = 2;
hasFlushed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
optional bool flushed = 2;
hasFlushed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponseOrBuilder
optional bool flushed = 2;
hasFlushSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
optional uint64 flush_sequence_number = 4;
hasFlushSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
optional uint64 flush_sequence_number = 4;
hasFlushSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
optional uint64 flush_sequence_number = 4;
hasFollowingKvCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
optional uint32 following_kv_count = 7;
hasFollowingKvCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
optional uint32 following_kv_count = 7;
hasFollowingKvCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
optional uint32 following_kv_count = 7;
hasForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest.Builder
optional bool force = 1;
hasForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest
optional bool force = 1;
hasForce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequestOrBuilder
optional bool force = 1;
hasForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
optional bool force = 2 [default = false];
hasForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
optional bool force = 2 [default = false];
hasForce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequestOrBuilder
optional bool force = 2 [default = false];
hasForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
optional bool forcible = 3 [default = false];
hasForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
optional bool forcible = 3 [default = false];
hasForcible() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
optional bool forcible = 3 [default = false];
hasForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
optional bool forcible = 3 [default = false];
hasForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
optional bool forcible = 3 [default = false];
hasForcible() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequestOrBuilder
optional bool forcible = 3 [default = false];
hasFoundKV() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
hasFreeSpace() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
hasFrom() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
optional uint64 from = 1;
hasFrom() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
optional uint64 from = 1;
hasFrom() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRangeOrBuilder
optional uint64 from = 1;
hasFsToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
required .DelegationToken fs_token = 3;
hasFsToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
required .DelegationToken fs_token = 3;
hasFsToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
required .DelegationToken fs_token = 3;
hasGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
optional .GenericExceptionMessage generic_exception = 2;
hasGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
optional .GenericExceptionMessage generic_exception = 2;
hasGenericException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
optional .GenericExceptionMessage generic_exception = 2;
hasGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
optional .Get get = 3;
hasGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
optional .Get get = 3;
hasGet() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
optional .Get get = 3;
hasGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
required .Get get = 2;
hasGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
required .Get get = 2;
hasGet() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
required .Get get = 2;
hasGlobalPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
optional .GlobalPermission global_permission = 2;
hasGlobalPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
optional .GlobalPermission global_permission = 2;
hasGlobalPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
optional .GlobalPermission global_permission = 2;
hash - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The hash value for this entries key
hash - Variable in class org.apache.hadoop.hbase.util.AbstractByteRange
Variable for lazy-caching the hashCode of this range.
hash - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Hash Function
Hash - Class in org.apache.hadoop.hbase.util
This class represents a common API for hashing functions.
Hash() - Constructor for class org.apache.hadoop.hbase.util.Hash
 
hash(byte[]) - Method in class org.apache.hadoop.hbase.util.Hash
Calculate a hash using all bytes from the input argument, and a seed of -1.
hash(byte[], int) - Method in class org.apache.hadoop.hbase.util.Hash
Calculate a hash using all bytes from the input argument, and a provided seed value.
hash(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Hash
Calculate a hash using bytes from 0 to length, and the provided seed value
hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.Hash
Calculate a hash using bytes from offset to offset + length, and the provided seed value.
hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.JenkinsHash
taken from hashlittle() -- hash a variable-length key into a 32-bit value
hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.MurmurHash
 
hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.MurmurHash3
Returns the MurmurHash3_x86_32 hash.
hash128(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the MD5 digest of the concatenation of the supplied arguments.
hash128(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the MD5 digest of the concatenation of the supplied arguments.
hash256(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the SHA-256 digest of the concatenation of the supplied arguments.
hash256(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Return the SHA-256 digest of the concatenation of the supplied arguments.
HASH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
 
HASH_NONCE_GRACE_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
 
hasHasCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
optional bool has_compression = 1;
hasHasCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
optional bool has_compression = 1;
hasHasCompression() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
optional bool has_compression = 1;
hasHash() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
optional bytes hash = 5;
hasHash() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
optional bytes hash = 5;
hasHash() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
optional bytes hash = 5;
hasHasTagCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
optional bool has_tag_compression = 3;
hasHasTagCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
optional bool has_tag_compression = 3;
hasHasTagCompression() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
optional bool has_tag_compression = 3;
hasHbaseVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
optional .HBaseVersionFileContent hbase_version = 1;
hasHbaseVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
optional .HBaseVersionFileContent hbase_version = 1;
hasHbaseVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
optional .HBaseVersionFileContent hbase_version = 1;
hashCode(Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
Returns a hash code that is always the same for two Cells having a matching equals(..) result.
hashCode() - Method in class org.apache.hadoop.hbase.client.Action
 
hashCode() - Method in class org.apache.hadoop.hbase.client.Get
 
hashCode() - Method in class org.apache.hadoop.hbase.client.Increment
 
hashCode() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
hashCode() - Method in class org.apache.hadoop.hbase.client.RowMutations
 
hashCode() - Method in class org.apache.hadoop.hbase.ClusterStatus
 
hashCode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
hashCode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
 
hashCode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
Generated by Eclipse
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse
 
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.FileLink
 
hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
hashCode() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
hashCode() - Method in class org.apache.hadoop.hbase.io.Reference
 
hashCode() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
hashCode(User, String, InetSocketAddress) - Static method in class org.apache.hadoop.hbase.ipc.ConnectionId
 
hashCode() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg
 
hashCode() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProto
 
hashCode() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto
 
hashCode() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyRequestProto
 
hashCode() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyResponseProto
 
hashCode() - Method in class org.apache.hadoop.hbase.KeyValue
In line with KeyValue.equals(Object), only uses the key portion, not the value.
hashCode() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
hashCode() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
hashCode() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
 
hashCode() - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
 
hashCode() - Method in class org.apache.hadoop.hbase.master.RegionPlan
 
hashCode() - Method in class org.apache.hadoop.hbase.master.RegionState
Don't count timestamp in hash code calculation
hashCode() - Method in class org.apache.hadoop.hbase.procedure.ProcedureManager
 
hashCode() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
 
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.GetUserPermissionsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
 
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.NamespacePermission
 
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.TablePermission
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.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.UpdateConfigurationRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
 
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.GetAuthenticationTokenRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
 
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.WhoAmIRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
 
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.CellVisibility
 
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.CoprocessorServiceResult
 
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.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.RegionAction
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
 
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.RegionLoad
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
 
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.LongComparator
 
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.EncryptionProtos.WrappedKey
 
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.Filter
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter
 
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.MultiRowRangeFilter
 
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.RowRange
 
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.ColumnFamilySchema
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
 
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.NamespaceDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
 
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.TableName
 
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.HBaseProtos.UUID
 
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.MapReduceProtos.TableSnapshotRegionSplit
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
 
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.MasterProtos.IsNormalizerEnabledRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerState
 
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.RegionStateTransition
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
 
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.ProcessRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
 
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.RPCProtos.VersionInfo
 
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.DelegationToken
 
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.SnapshotProtos.SnapshotDataManifest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
 
hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer
 
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.MetaRegionServer
 
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.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.MetricsRegionSourceImpl
 
hashCode() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.security.access.Permission
 
hashCode() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hashCode() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
 
hashCode() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
 
hashCode() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
hashCode() - Method in class org.apache.hadoop.hbase.security.User
 
hashCode() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
 
hashCode() - Method in class org.apache.hadoop.hbase.ServerName
 
hashCode() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
hashCode() - Method in class org.apache.hadoop.hbase.TableName
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.AlreadyExists
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.IllegalArgument
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.IOError
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.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.getScannerResults_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIOError
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
 
hashCode() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
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.wal.WALKey
 
hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
 
hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.DeleteNodeFailSilent
 
hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
 
hashCode() - Method in class org.apache.hadoop.metrics2.util.MetricQuantile
 
hashCodeIgnoreMvcc(Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
Returns a hash code that is always the same for two Cells having a matching equals(..) result.
hashCount - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Number of hash functions
hasHeapOccupancy() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
optional int32 heapOccupancy = 2 [default = 0];
hasHeapOccupancy() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
optional int32 heapOccupancy = 2 [default = 0];
hasHeapOccupancy() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStatsOrBuilder
optional int32 heapOccupancy = 2 [default = 0];
hasHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int32 heapSizeMB = 4;
hasHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
optional int32 heapSizeMB = 4;
hasHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
optional int32 heapSizeMB = 4;
hasHeartbeatMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
optional bool heartbeat_message = 9;
hasHeartbeatMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
optional bool heartbeat_message = 9;
hasHeartbeatMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
optional bool heartbeat_message = 9;
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
 
hasHfile() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
optional string hfile = 3;
hasHfile() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
optional string hfile = 3;
hasHfile() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
optional string hfile = 3;
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
required string host_name = 1;
hasHostName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
required string host_name = 1;
hasHostName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
required string host_name = 1;
hasHostname() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
optional string hostname = 3;
hasHostname() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
optional string hostname = 3;
hasHostname() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
optional string hostname = 3;
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
required int32 id = 1;
hasId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
required int32 id = 1;
hasId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
required int32 id = 1;
hasId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional int64 id = 4;
hasId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
optional int64 id = 4;
hasId() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
optional int64 id = 4;
hasId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
hasIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
optional bytes identifier = 1;
hasIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
optional bytes identifier = 1;
hasIdentifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
optional bytes identifier = 1;
hasIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
optional bytes identifier = 1;
hasIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
optional bytes identifier = 1;
hasIdentifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
optional bytes identifier = 1;
hasIfOlderThanTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
optional uint64 if_older_than_ts = 2;
hasIfOlderThanTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
optional uint64 if_older_than_ts = 2;
hasIfOlderThanTs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
optional uint64 if_older_than_ts = 2;
hasIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
optional bool include_sys_tables = 3 [default = false];
hasIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
optional bool include_sys_tables = 3 [default = false];
hasIncludeSysTables() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
optional bool include_sys_tables = 3 [default = false];
hasIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
optional bool include_sys_tables = 2 [default = false];
hasIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
optional bool include_sys_tables = 2 [default = false];
hasIncludeSysTables() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequestOrBuilder
optional bool include_sys_tables = 2 [default = false];
hasIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
optional uint32 index = 1;
hasIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
optional uint32 index = 1;
hasIndex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
optional uint32 index = 1;
hasIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
optional uint32 index = 1;
hasIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
optional uint32 index = 1;
hasIndex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
optional uint32 index = 1;
hasInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
optional int32 infoPort = 1;
hasInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
optional int32 infoPort = 1;
hasInfoPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfoOrBuilder
optional int32 infoPort = 1;
hasInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
optional uint32 info_port = 3;
hasInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
optional uint32 info_port = 3;
hasInfoPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MasterOrBuilder
optional uint32 info_port = 3;
hasInfoServerPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
optional uint32 info_server_port = 9;
hasInfoServerPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
optional uint32 info_server_port = 9;
hasInfoServerPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
optional uint32 info_server_port = 9;
hasInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional bool inMemory = 4;
hasInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
optional bool inMemory = 4;
hasInMemory() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
optional bool inMemory = 4;
hasInstance() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
optional string instance = 2;
hasInstance() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
optional string instance = 2;
hasInstance() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
optional string instance = 2;
hasInterpreterClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
required string interpreter_class_name = 1;
hasInterpreterClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
required string interpreter_class_name = 1;
hasInterpreterClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequestOrBuilder
required string interpreter_class_name = 1;
hasInterpreterSpecificBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
optional bytes interpreter_specific_bytes = 3;
hasInterpreterSpecificBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
optional bytes interpreter_specific_bytes = 3;
hasInterpreterSpecificBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequestOrBuilder
optional bytes interpreter_specific_bytes = 3;
hasIsMasterRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
required bool is_master_running = 1;
hasIsMasterRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
required bool is_master_running = 1;
hasIsMasterRunning() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponseOrBuilder
required bool is_master_running = 1;
hasIsProcedureAborted() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
required bool is_procedure_aborted = 1;
hasIsProcedureAborted() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
required bool is_procedure_aborted = 1;
hasIsProcedureAborted() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponseOrBuilder
required bool is_procedure_aborted = 1;
hasIsRecovering() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
optional bool isRecovering = 3;
hasIsRecovering() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
optional bool isRecovering = 3;
hasIsRecovering() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
optional bool isRecovering = 3;
hasIsShared() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
optional bool is_shared = 4;
hasIsShared() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
optional bool is_shared = 4;
hasIsShared() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
optional bool is_shared = 4;
hasIssueDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
optional int64 issue_date = 4;
hasIssueDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
optional int64 issue_date = 4;
hasIssueDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
optional int64 issue_date = 4;
hasIv() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
optional bytes iv = 4;
hasIv() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
optional bytes iv = 4;
hasIv() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
optional bytes iv = 4;
hasJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jerseyVersion = 5;
hasJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string jerseyVersion = 5;
hasJerseyVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string jerseyVersion = 5;
hasJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string jvmVersion = 2;
hasJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string jvmVersion = 2;
hasJvmVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string jvmVersion = 2;
hasKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
required .WALKey key = 1;
hasKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
required .WALKey key = 1;
hasKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
required .WALKey key = 1;
hasKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
required bytes key = 3;
hasKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
required bytes key = 3;
hasKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
required bytes key = 3;
hasKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
required bytes key = 1;
hasKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
required bytes key = 1;
hasKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
required bytes key = 1;
hasKeyId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
required int32 key_id = 3;
hasKeyId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
required int32 key_id = 3;
hasKeyId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
required int32 key_id = 3;
hasKeyType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
optional .CellType key_type = 5;
hasKeyType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
optional .CellType key_type = 5;
hasKeyType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
optional .CellType key_type = 5;
hasKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
required .TokenIdentifier.Kind kind = 1;
hasKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
required .TokenIdentifier.Kind kind = 1;
hasKind() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
required .TokenIdentifier.Kind kind = 1;
hasKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
optional string kind = 3;
hasKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
optional string kind = 3;
hasKind() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
optional string kind = 3;
hasLabel() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
required bytes label = 1;
hasLabel() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
required bytes label = 1;
hasLabel() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelOrBuilder
required bytes label = 1;
hasLabels() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
hasLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
optional uint64 last_data_block_offset = 10;
hasLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
optional uint64 last_data_block_offset = 10;
hasLastDataBlockOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
optional uint64 last_data_block_offset = 10;
hasLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
required uint64 last_flushed_sequence_id = 1;
hasLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
required uint64 last_flushed_sequence_id = 1;
hasLastFlushedSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIdsOrBuilder
required uint64 last_flushed_sequence_id = 1;
hasLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
required uint64 last_flushed_sequence_id = 1;
hasLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
required uint64 last_flushed_sequence_id = 1;
hasLastFlushedSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponseOrBuilder
required uint64 last_flushed_sequence_id = 1;
hasLastFlushTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
required uint64 last_flush_time = 1;
hasLastFlushTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
required uint64 last_flush_time = 1;
hasLastFlushTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponseOrBuilder
required uint64 last_flush_time = 1;
hasLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint64 last_major_compaction_ts = 17 [default = 0];
hasLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint64 last_major_compaction_ts = 17 [default = 0];
hasLastMajorCompactionTs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint64 last_major_compaction_ts = 17 [default = 0];
hasLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
optional uint64 last_update = 3;
hasLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
optional uint64 last_update = 3;
hasLastUpdate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
optional uint64 last_update = 3;
hasLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
required uint64 last_update = 8;
hasLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
required uint64 last_update = 8;
hasLastUpdate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
required uint64 last_update = 8;
hasLatestVersionOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
optional bool latest_version_only = 6;
hasLatestVersionOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
optional bool latest_version_only = 6;
hasLatestVersionOnly() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
optional bool latest_version_only = 6;
hasLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
 
hasLeastSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
required uint64 least_sig_bits = 1;
hasLeastSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
required uint64 least_sig_bits = 1;
hasLeastSigBits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUIDOrBuilder
required uint64 least_sig_bits = 1;
hasLenAsVal() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
required bool len_as_val = 1;
hasLenAsVal() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
required bool len_as_val = 1;
hasLenAsVal() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilterOrBuilder
required bool len_as_val = 1;
hasLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
required uint32 length = 2;
hasLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
required uint32 length = 2;
hasLength() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
required uint32 length = 2;
hasLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
optional uint32 length = 1;
hasLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
optional uint32 length = 1;
hasLength() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMetaOrBuilder
optional uint32 length = 1;
hasLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
required int32 limit = 1;
hasLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
required int32 limit = 1;
hasLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilterOrBuilder
required int32 limit = 1;
hasLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
required int32 limit = 1;
hasLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
required int32 limit = 1;
hasLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilterOrBuilder
required int32 limit = 1;
hasLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
optional int32 line_number = 4;
hasLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
optional int32 line_number = 4;
hasLineNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
optional int32 line_number = 4;
hasLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
optional .ServerLoad load = 2;
hasLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
optional .ServerLoad load = 2;
hasLoad() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
optional .ServerLoad load = 2;
hasLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional bool load_column_families_on_demand = 13;
hasLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional bool load_column_families_on_demand = 13;
hasLoadColumnFamiliesOnDemand() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional bool load_column_families_on_demand = 13;
hasLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
required bool loaded = 1;
hasLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
required bool loaded = 1;
hasLoaded() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponseOrBuilder
required bool loaded = 1;
hasLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
required bool loaded = 1;
hasLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
required bool loaded = 1;
hasLoaded() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponseOrBuilder
required bool loaded = 1;
hasLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
optional uint64 load_on_open_data_offset = 2;
hasLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
optional uint64 load_on_open_data_offset = 2;
hasLoadOnOpenDataOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
optional uint64 load_on_open_data_offset = 2;
hasLoadStats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
optional .RegionLoadStats loadStats = 5;
hasLoadStats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
optional .RegionLoadStats loadStats = 5;
hasLoadStats() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
optional .RegionLoadStats loadStats = 5;
hasLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional string location = 5;
hasLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
optional string location = 5;
hasLocation() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
optional string location = 5;
hasLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
required string lock_owner = 1;
hasLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
required string lock_owner = 1;
hasLockOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLockOrBuilder
required string lock_owner = 1;
hasLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
optional .ServerName lock_owner = 2;
hasLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
optional .ServerName lock_owner = 2;
hasLockOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
optional .ServerName lock_owner = 2;
hasLogId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
required uint64 log_id = 3;
hasLogId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
required uint64 log_id = 3;
hasLogId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeaderOrBuilder
required uint64 log_id = 3;
hasLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
optional uint64 log_sequence_number = 4;
hasLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
optional uint64 log_sequence_number = 4;
hasLogSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
optional uint64 log_sequence_number = 4;
hasLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
required uint64 log_sequence_number = 3;
hasLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
required uint64 log_sequence_number = 3;
hasLogSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
required uint64 log_sequence_number = 3;
hasLongMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
required int64 long_msg = 1;
hasLongMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
required int64 long_msg = 1;
hasLongMsg() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsgOrBuilder
required int64 long_msg = 1;
hasMajor() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
optional bool major = 2;
hasMajor() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
optional bool major = 2;
hasMajor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
optional bool major = 2;
hasMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
optional .ServerName master = 7;
hasMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
optional .ServerName master = 7;
hasMaster() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
optional .ServerName master = 7;
hasMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
required .ServerName master = 1;
hasMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
required .ServerName master = 1;
hasMaster() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MasterOrBuilder
required .ServerName master = 1;
hasMaster() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
Check if there is a master available.
hasMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
optional uint64 master_system_time = 4;
hasMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
optional uint64 master_system_time = 4;
hasMasterSystemTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
optional uint64 master_system_time = 4;
hasMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
optional uint64 master_system_time = 5;
hasMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
optional uint64 master_system_time = 5;
hasMasterSystemTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
optional uint64 master_system_time = 5;
hasMaxColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
optional bytes max_column = 3;
hasMaxColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
optional bytes max_column = 3;
hasMaxColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
optional bytes max_column = 3;
hasMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
optional bool max_column_inclusive = 4;
hasMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
optional bool max_column_inclusive = 4;
hasMaxColumnInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
optional bool max_column_inclusive = 4;
hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
optional uint32 max_heap_MB = 4;
hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
optional uint32 max_heap_MB = 4;
hasMaxHeapMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
optional uint32 max_heap_MB = 4;
hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int32 maxHeapSizeMB = 5;
hasMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
optional int32 maxHeapSizeMB = 5;
hasMaxHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
optional int32 maxHeapSizeMB = 5;
hasMaxResultSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional uint64 max_result_size = 10;
hasMaxResultSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional uint64 max_result_size = 10;
hasMaxResultSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional uint64 max_result_size = 10;
hasMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
optional uint32 max_versions = 6 [default = 1];
hasMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
optional uint32 max_versions = 6 [default = 1];
hasMaxVersions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
optional uint32 max_versions = 6 [default = 1];
hasMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional uint32 max_versions = 7 [default = 1];
hasMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional uint32 max_versions = 7 [default = 1];
hasMaxVersions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional uint32 max_versions = 7 [default = 1];
hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional int32 maxVersions = 4;
hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional int32 maxVersions = 4;
hasMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional int32 maxVersions = 4;
hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int32 maxVersions = 7;
hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int32 maxVersions = 7;
hasMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int32 maxVersions = 7;
hasMayInterruptIfRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
optional bool mayInterruptIfRunning = 2 [default = true];
hasMayInterruptIfRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
optional bool mayInterruptIfRunning = 2 [default = true];
hasMayInterruptIfRunning() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequestOrBuilder
optional bool mayInterruptIfRunning = 2 [default = true];
hasMemstoreLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
optional int32 memstoreLoad = 1 [default = 0];
hasMemstoreLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
optional int32 memstoreLoad = 1 [default = 0];
hasMemstoreLoad() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStatsOrBuilder
optional int32 memstoreLoad = 1 [default = 0];
hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint32 memstore_size_MB = 6;
hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint32 memstore_size_MB = 6;
hasMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint32 memstore_size_MB = 6;
hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 memstoreSizeMB = 5;
hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 memstoreSizeMB = 5;
hasMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 memstoreSizeMB = 5;
hasMessage() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProto.Builder
required string message = 1;
hasMessage() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProto
required string message = 1;
hasMessage() - Method in interface org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProtoOrBuilder
required string message = 1;
hasMessage() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto.Builder
required string message = 1;
hasMessage() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto
required string message = 1;
hasMessage() - Method in interface org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProtoOrBuilder
required string message = 1;
hasMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
optional string message = 2;
hasMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
optional string message = 2;
hasMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
optional string message = 2;
hasMetaIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
optional uint32 meta_index_count = 6;
hasMetaIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
optional uint32 meta_index_count = 6;
hasMetaIndexCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
optional uint32 meta_index_count = 6;
hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
required string method_name = 3;
hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
required string method_name = 3;
hasMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
required string method_name = 3;
hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
optional string method_name = 2;
hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
optional string method_name = 2;
hasMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
optional string method_name = 2;
hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
optional string method_name = 3;
hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
optional string method_name = 3;
hasMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
optional string method_name = 3;
hasMinColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
optional bytes min_column = 1;
hasMinColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
optional bytes min_column = 1;
hasMinColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
optional bytes min_column = 1;
hasMinColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
optional bool min_column_inclusive = 2;
hasMinColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
optional bool min_column_inclusive = 2;
hasMinColumnInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
optional bool min_column_inclusive = 2;
hasMinProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
required uint64 min_proc_id = 4;
hasMinProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
required uint64 min_proc_id = 4;
hasMinProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeaderOrBuilder
required uint64 min_proc_id = 4;
hasMode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN];
hasMode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN];
hasMode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN];
hasModifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
required .TableSchema modified_table_schema = 3;
hasModifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
required .TableSchema modified_table_schema = 3;
hasModifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
required .TableSchema modified_table_schema = 3;
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
optional bool more_results = 3;
hasMoreResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
optional bool more_results = 3;
hasMoreResults() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
optional bool more_results = 3;
hasMoreResultsContext() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
Did the server respond with information about whether more results might exist.
hasMoreResultsInRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
optional bool more_results_in_region = 8;
hasMoreResultsInRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
optional bool more_results_in_region = 8;
hasMoreResultsInRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
optional bool more_results_in_region = 8;
hasMoreValues() - Method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
 
hasMoreValues(ScannerContext.NextState) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
 
hasMostSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
required uint64 most_sig_bits = 2;
hasMostSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
required uint64 most_sig_bits = 2;
hasMostSigBits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUIDOrBuilder
required uint64 most_sig_bits = 2;
hasMutateType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
optional .MutationProto.MutationType mutate_type = 2;
hasMutateType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
optional .MutationProto.MutationType mutate_type = 2;
hasMutateType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
optional .MutationProto.MutationType mutate_type = 2;
hasMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
optional .MutationProto mutation = 2;
hasMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
optional .MutationProto mutation = 2;
hasMutation() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
optional .MutationProto mutation = 2;
hasMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
required .MutationProto mutation = 2;
hasMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
required .MutationProto mutation = 2;
hasMutation() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
required .MutationProto mutation = 2;
hasMVCCInfo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
 
hasMVCCInfo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
 
hasName() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequest.Builder
optional string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequest
optional string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequestOrBuilder
optional string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ComparatorOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
required bytes name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
required bytes name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
required bytes name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CoprocessorOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPairOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
optional string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
optional string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64PairOrBuilder
optional string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
required bytes name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
required bytes name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptorOrBuilder
required bytes name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPairOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFileOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
required bytes name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
required bytes name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
required bytes name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
required string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
required string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional string name = 1;
hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
optional string name = 1;
hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
optional string name = 1;
hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
required bytes namespace = 1;
hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
required bytes namespace = 1;
hasNamespace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableNameOrBuilder
required bytes namespace = 1;
hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
optional string namespace = 4;
hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
optional string namespace = 4;
hasNamespace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
optional string namespace = 4;
hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
optional string namespace = 3;
hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
optional string namespace = 3;
hasNamespace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequestOrBuilder
optional string namespace = 3;
hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
optional string namespace = 3;
hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
optional string namespace = 3;
hasNamespace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
optional string namespace = 3;
hasNamespace() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
required .NamespaceDescriptor namespaceDescriptor = 1;
hasNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
required .NamespaceDescriptor namespaceDescriptor = 1;
hasNamespaceDescriptor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequestOrBuilder
required .NamespaceDescriptor namespaceDescriptor = 1;
hasNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
required .NamespaceDescriptor namespaceDescriptor = 1;
hasNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
required .NamespaceDescriptor namespaceDescriptor = 1;
hasNamespaceDescriptor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponseOrBuilder
required .NamespaceDescriptor namespaceDescriptor = 1;
hasNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
required .NamespaceDescriptor namespaceDescriptor = 1;
hasNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
required .NamespaceDescriptor namespaceDescriptor = 1;
hasNamespaceDescriptor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequestOrBuilder
required .NamespaceDescriptor namespaceDescriptor = 1;
hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
optional bytes namespace_name = 3;
hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
optional bytes namespace_name = 3;
hasNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequestOrBuilder
optional bytes namespace_name = 3;
hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
optional bytes namespace_name = 1;
hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
optional bytes namespace_name = 1;
hasNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermissionOrBuilder
optional bytes namespace_name = 1;
hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
required string namespaceName = 1;
hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
required string namespaceName = 1;
hasNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequestOrBuilder
required string namespaceName = 1;
hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
required string namespaceName = 1;
hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
required string namespaceName = 1;
hasNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequestOrBuilder
required string namespaceName = 1;
hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
required string namespaceName = 1;
hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
required string namespaceName = 1;
hasNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequestOrBuilder
required string namespaceName = 1;
hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
required string namespaceName = 1;
hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
required string namespaceName = 1;
hasNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequestOrBuilder
required string namespaceName = 1;
hasNamespacePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
optional .NamespacePermission namespace_permission = 3;
hasNamespacePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
optional .NamespacePermission namespace_permission = 3;
hasNamespacePermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
optional .NamespacePermission namespace_permission = 3;
hasNext() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
 
hasNext() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
hasNext() - Method in class org.apache.hadoop.hbase.types.StructIterator
 
hasNext() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
 
hasNextCallSeq() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
optional uint64 next_call_seq = 6;
hasNextCallSeq() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
optional uint64 next_call_seq = 6;
hasNextCallSeq() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
optional uint64 next_call_seq = 6;
hasNonce() - Method in class org.apache.hadoop.hbase.client.Action
 
hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
optional uint64 nonce = 9;
hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
optional uint64 nonce = 9;
hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
optional uint64 nonce = 9;
hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
optional uint64 nonce = 3;
hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
optional uint64 nonce = 3;
hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequestOrBuilder
optional uint64 nonce = 3;
hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
optional uint64 nonce = 5;
hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
optional uint64 nonce = 5;
hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
optional uint64 nonce = 5;
hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
optional uint64 nonce = 10;
hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
optional uint64 nonce = 10;
hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
optional uint64 nonce = 10;
hasNonceGroup() - Method in class org.apache.hadoop.hbase.client.MultiAction
 
hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
optional uint64 nonceGroup = 2;
hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
optional uint64 nonceGroup = 2;
hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
optional uint64 nonceGroup = 2;
hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
optional uint64 nonce_group = 4;
hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
optional uint64 nonce_group = 4;
hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
optional uint64 nonce_group = 4;
hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
optional uint64 nonce_group = 2;
hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
optional uint64 nonce_group = 2;
hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequestOrBuilder
optional uint64 nonce_group = 2;
hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
optional uint64 nonce_group = 4;
hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
optional uint64 nonce_group = 4;
hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
optional uint64 nonce_group = 4;
hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
optional uint64 nonceGroup = 9;
hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
optional uint64 nonceGroup = 9;
hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
optional uint64 nonceGroup = 9;
hasNormalizerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerState.Builder
optional bool normalizer_on = 1;
hasNormalizerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerState
optional bool normalizer_on = 1;
hasNormalizerOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerStateOrBuilder
optional bool normalizer_on = 1;
hasNormalizerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse.Builder
required bool normalizer_ran = 1;
hasNormalizerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse
required bool normalizer_ran = 1;
hasNormalizerRan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponseOrBuilder
required bool normalizer_ran = 1;
hasNullColumnInQuery() - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
 
hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
optional uint64 number_of_requests = 1;
hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
optional uint64 number_of_requests = 1;
hasNumberOfRequests() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
optional uint64 number_of_requests = 1;
hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasNumberOfRows() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
optional uint32 number_of_rows = 4;
hasNumberOfRows() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
optional uint32 number_of_rows = 4;
hasNumberOfRows() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
optional uint32 number_of_rows = 4;
hasNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
optional uint32 num_data_index_levels = 8;
hasNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
optional uint32 num_data_index_levels = 8;
hasNumDataIndexLevels() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
optional uint32 num_data_index_levels = 8;
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
optional bool offline = 5;
hasOffline() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
optional bool offline = 5;
hasOffline() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
optional bool offline = 5;
hasOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
optional int32 offset = 2;
hasOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
optional int32 offset = 2;
hasOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilterOrBuilder
optional int32 offset = 2;
hasOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
required bool on = 1;
hasOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
required bool on = 1;
hasOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequestOrBuilder
required bool on = 1;
hasOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningRequest.Builder
required bool on = 1;
hasOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningRequest
required bool on = 1;
hasOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningRequestOrBuilder
required bool on = 1;
hasOpenForDistributedLogReplay() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
optional bool openForDistributedLogReplay = 4;
hasOpenForDistributedLogReplay() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
optional bool openForDistributedLogReplay = 4;
hasOpenForDistributedLogReplay() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
optional bool openForDistributedLogReplay = 4;
hasOpenSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
optional uint64 open_seq_num = 3;
hasOpenSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
optional uint64 open_seq_num = 3;
hasOpenSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransitionOrBuilder
optional uint64 open_seq_num = 3;
hasOperator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
required .FilterList.Operator operator = 1;
hasOperator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
required .FilterList.Operator operator = 1;
hasOperator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
required .FilterList.Operator operator = 1;
hasOrdinal() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
optional uint32 ordinal = 2;
hasOrdinal() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
optional uint32 ordinal = 2;
hasOrdinal() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelOrBuilder
optional uint32 ordinal = 2;
hasOrigSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
optional uint64 orig_sequence_number = 11;
hasOrigSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
optional uint64 orig_sequence_number = 11;
hasOrigSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
optional uint64 orig_sequence_number = 11;
hasOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string osVersion = 3;
hasOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string osVersion = 3;
hasOsVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string osVersion = 3;
hasOwner() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
hasOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
optional string owner = 6;
hasOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
optional string owner = 6;
hasOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
optional string owner = 6;
hasOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
optional string owner = 5;
hasOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
optional string owner = 5;
hasOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
optional string owner = 5;
hasPageSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
required int64 page_size = 1;
hasPageSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
required int64 page_size = 1;
hasPageSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilterOrBuilder
required int64 page_size = 1;
hasParent() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
hasParentId() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
hasParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
optional uint64 parent_id = 2;
hasParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
optional uint64 parent_id = 2;
hasParentId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
optional uint64 parent_id = 2;
hasParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
optional int64 parent_id = 2;
hasParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
optional int64 parent_id = 2;
hasParentId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfoOrBuilder
optional int64 parent_id = 2;
hasPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
optional bool partial = 5 [default = false];
hasPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
optional bool partial = 5 [default = false];
hasPartial() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
optional bool partial = 5 [default = false];
hasPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
optional bytes password = 2;
hasPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
optional bytes password = 2;
hasPassword() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
optional bytes password = 2;
hasPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
optional bytes password = 2;
hasPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
optional bytes password = 2;
hasPassword() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
optional bytes password = 2;
hasPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
required string path = 2;
hasPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
required string path = 2;
hasPath() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPathOrBuilder
required string path = 2;
hasPattern() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
required string pattern = 1;
hasPattern() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
required string pattern = 1;
hasPattern() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
required string pattern = 1;
hasPatternFlags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
required int32 pattern_flags = 2;
hasPatternFlags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
required int32 pattern_flags = 2;
hasPatternFlags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
required int32 pattern_flags = 2;
hasPayload() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
optional bytes payload = 5;
hasPayload() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
optional bytes payload = 5;
hasPayload() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
optional bytes payload = 5;
hasPeerID() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
required string peerID = 1;
hasPeerID() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
required string peerID = 1;
hasPeerID() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
required string peerID = 1;
hasPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
required .Permission permission = 3;
hasPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
required .Permission permission = 3;
hasPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionOrBuilder
required .Permission permission = 3;
hasPerson() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
required bytes person = 1;
hasPerson() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest
required bytes person = 1;
hasPerson() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequestOrBuilder
required bytes person = 1;
hasPong() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse.Builder
required string pong = 1;
hasPong() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse
required string pong = 1;
hasPong() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponseOrBuilder
required string pong = 1;
hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
optional uint32 port = 2;
hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
optional uint32 port = 2;
hasPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
optional uint32 port = 2;
hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
required uint32 port = 1;
hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
required uint32 port = 1;
hasPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
required uint32 port = 1;
hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
optional int32 port = 4;
hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
optional int32 port = 4;
hasPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
optional int32 port = 4;
hasPosition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
required int64 position = 1;
hasPosition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
required int64 position = 1;
hasPosition() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPositionOrBuilder
required int64 position = 1;
hasPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
required bytes prefix = 1;
hasPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
required bytes prefix = 1;
hasPrefix() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilterOrBuilder
required bytes prefix = 1;
hasPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
optional bytes prefix = 1;
hasPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
optional bytes prefix = 1;
hasPrefix() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilterOrBuilder
optional bytes prefix = 1;
hasPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
required bool preserve_splits = 2;
hasPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
required bool preserve_splits = 2;
hasPreserveSplits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
required bool preserve_splits = 2;
hasPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
optional bool preserveSplits = 2 [default = false];
hasPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
optional bool preserveSplits = 2 [default = false];
hasPreserveSplits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequestOrBuilder
optional bool preserveSplits = 2 [default = false];
hasPrevBalanceValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
optional bool prev_balance_value = 1;
hasPrevBalanceValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
optional bool prev_balance_value = 1;
hasPrevBalanceValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponseOrBuilder
optional bool prev_balance_value = 1;
hasPreviousFanNodes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
 
hasPrevNormalizerValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse.Builder
optional bool prev_normalizer_value = 1;
hasPrevNormalizerValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse
optional bool prev_normalizer_value = 1;
hasPrevNormalizerValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponseOrBuilder
optional bool prev_normalizer_value = 1;
hasPrevValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
optional bool prev_value = 1;
hasPrevValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
optional bool prev_value = 1;
hasPrevValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponseOrBuilder
optional bool prev_value = 1;
hasPriority() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
optional uint32 priority = 6;
hasPriority() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
optional uint32 priority = 6;
hasPriority() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
optional uint32 priority = 6;
hasProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
required .ProcedureDescription procedure = 1;
hasProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
required .ProcedureDescription procedure = 1;
hasProcedure() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequestOrBuilder
required .ProcedureDescription procedure = 1;
hasProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
optional .ProcedureDescription procedure = 1;
hasProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
optional .ProcedureDescription procedure = 1;
hasProcedure() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequestOrBuilder
optional .ProcedureDescription procedure = 1;
hasProcedureSupport() - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
 
hasProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
optional bool processed = 2;
hasProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
optional bool processed = 2;
hasProcessed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponseOrBuilder
optional bool processed = 2;
hasProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
optional bool processed = 2;
hasProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
optional bool processed = 2;
hasProcessed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponseOrBuilder
optional bool processed = 2;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
required uint64 proc_id = 1;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
required uint64 proc_id = 1;
hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequestOrBuilder
required uint64 proc_id = 1;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
optional uint64 proc_id = 1;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
optional uint64 proc_id = 1;
hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponseOrBuilder
optional uint64 proc_id = 1;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
optional uint64 proc_id = 1;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
optional uint64 proc_id = 1;
hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponseOrBuilder
optional uint64 proc_id = 1;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
optional uint64 proc_id = 1;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
optional uint64 proc_id = 1;
hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponseOrBuilder
optional uint64 proc_id = 1;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
optional uint64 proc_id = 1;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
optional uint64 proc_id = 1;
hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponseOrBuilder
optional uint64 proc_id = 1;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
required uint64 proc_id = 1;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
required uint64 proc_id = 1;
hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequestOrBuilder
required uint64 proc_id = 1;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
required uint64 proc_id = 3;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
required uint64 proc_id = 3;
hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
required uint64 proc_id = 3;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
optional uint64 proc_id = 3;
hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
optional uint64 proc_id = 3;
hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntryOrBuilder
optional uint64 proc_id = 3;
hasPurpose() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
optional string purpose = 5;
hasPurpose() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
optional string purpose = 5;
hasPurpose() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
optional string purpose = 5;
hasQualifier() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest.Builder
optional bytes qualifier = 2;
hasQualifier() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest
optional bytes qualifier = 2;
hasQualifier() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequestOrBuilder
optional bytes qualifier = 2;
hasQualifier() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest.Builder
optional bytes qualifier = 2;
hasQualifier() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest
optional bytes qualifier = 2;
hasQualifier() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequestOrBuilder
optional bytes qualifier = 2;
hasQualifier() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest.Builder
optional bytes qualifier = 2;
hasQualifier() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest
optional bytes qualifier = 2;
hasQualifier() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequestOrBuilder
optional bytes qualifier = 2;
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
optional bytes qualifier = 3;
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
optional bytes qualifier = 3;
hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermissionOrBuilder
optional bytes qualifier = 3;
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
optional bytes qualifier = 3;
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
optional bytes qualifier = 3;
hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
optional bytes qualifier = 3;
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
required bytes qualifier = 3;
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
required bytes qualifier = 3;
hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
required bytes qualifier = 3;
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
required bytes qualifier = 3;
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
required bytes qualifier = 3;
hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
required bytes qualifier = 3;
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
optional bytes qualifier = 1;
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
optional bytes qualifier = 1;
hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
optional bytes qualifier = 1;
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
required bytes qualifier = 2;
hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
required bytes qualifier = 2;
hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableNameOrBuilder
required bytes qualifier = 2;
hasQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
required .Reference.Range range = 2;
hasRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
required .Reference.Range range = 2;
hasRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.ReferenceOrBuilder
required .Reference.Range range = 2;
hasReadNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
optional .TimedQuota read_num = 5;
hasReadNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
optional .TimedQuota read_num = 5;
hasReadNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
optional .TimedQuota read_num = 5;
hasReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
optional bool readOnly = 5;
hasReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
optional bool readOnly = 5;
hasReadOnly() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
optional bool readOnly = 5;
hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint64 read_requests_count = 8;
hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint64 read_requests_count = 8;
hasReadRequestsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint64 read_requests_count = 8;
hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 readRequestsCount = 7;
hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int64 readRequestsCount = 7;
hasReadRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int64 readRequestsCount = 7;
hasReadSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
optional .TimedQuota read_size = 6;
hasReadSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
optional .TimedQuota read_size = 6;
hasReadSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
optional .TimedQuota read_size = 6;
hasRealUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
optional string real_user = 2;
hasRealUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
optional string real_user = 2;
hasRealUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformationOrBuilder
optional string real_user = 2;
hasReason() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
required string reason = 1;
hasReason() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
required string reason = 1;
hasReason() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequestOrBuilder
required string reason = 1;
hasReference() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
optional .Reference reference = 2;
hasReference() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
optional .Reference reference = 2;
hasReference() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFileOrBuilder
optional .Reference reference = 2;
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.
hasRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
optional string regex = 2;
hasRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
optional string regex = 2;
hasRegex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
optional string regex = 2;
hasRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
optional string regex = 1;
hasRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
optional string regex = 1;
hasRegex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequestOrBuilder
optional string regex = 1;
hasRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
optional string regex = 1;
hasRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
optional string regex = 1;
hasRegex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequestOrBuilder
optional string regex = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
required .RegionInfo region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
required .RegionInfo region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
required .RegionInfo region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
required .RegionInfo region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
required .RegionInfo region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfoOrBuilder
required .RegionInfo region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
optional .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
optional .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
optional .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
optional .RegionInfo region = 4;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
optional .RegionInfo region = 4;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplitOrBuilder
optional .RegionInfo region = 4;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
required .RegionSpecifier region = 1;
hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
required .RegionSpecifier region = 1;
hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequestOrBuilder
required .RegionSpecifier region = 1;
hasRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
required .RegionSpecifier region_a = 1;
hasRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
required .RegionSpecifier region_a = 1;
hasRegionA() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
required .RegionSpecifier region_a = 1;
hasRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
required .RegionSpecifier region_a = 1;
hasRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
required .RegionSpecifier region_a = 1;
hasRegionA() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequestOrBuilder
required .RegionSpecifier region_a = 1;
hasRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
required .RegionSpecifier region_b = 2;
hasRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
required .RegionSpecifier region_b = 2;
hasRegionB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
required .RegionSpecifier region_b = 2;
hasRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
required .RegionSpecifier region_b = 2;
hasRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
required .RegionSpecifier region_b = 2;
hasRegionB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequestOrBuilder
required .RegionSpecifier region_b = 2;
hasRegionId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
required uint64 region_id = 1;
hasRegionId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
required uint64 region_id = 1;
hasRegionId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
required uint64 region_id = 1;
hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
required .RegionInfo region_info = 1;
hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
required .RegionInfo region_info = 1;
hasRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
required .RegionInfo region_info = 1;
hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
required .RegionInfo regionInfo = 1;
hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
required .RegionInfo regionInfo = 1;
hasRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequestOrBuilder
required .RegionInfo regionInfo = 1;
hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
required .RegionInfo region_info = 1;
hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
required .RegionInfo region_info = 1;
hasRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
required .RegionInfo region_info = 1;
hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
required .RegionInfo region_info = 2;
hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
required .RegionInfo region_info = 2;
hasRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifestOrBuilder
required .RegionInfo region_info = 2;
hasRegionMemstoreReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
required bytes region_name = 1;
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
required bytes region_name = 1;
hasRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequestOrBuilder
required bytes region_name = 1;
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
optional bytes region_name = 7;
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
optional bytes region_name = 7;
hasRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
optional bytes region_name = 7;
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
optional bytes region_name = 6;
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
optional bytes region_name = 6;
hasRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
optional bytes region_name = 6;
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
optional bytes region_name = 7;
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
optional bytes region_name = 7;
hasRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
optional bytes region_name = 7;
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
required bytes region_name = 2;
hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
required bytes region_name = 2;
hasRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
required bytes region_name = 2;
hasRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional int32 regions = 3;
hasRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
optional int32 regions = 3;
hasRegions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
optional int32 regions = 3;
hasRegionSpecifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
required .RegionSpecifier region_specifier = 1;
hasRegionSpecifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
required .RegionSpecifier region_specifier = 1;
hasRegionSpecifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
required .RegionSpecifier region_specifier = 1;
hasRegionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
required .RegionState region_state = 2;
hasRegionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
required .RegionState region_state = 2;
hasRegionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
required .RegionState region_state = 2;
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
 
hasRemoveAll() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
optional bool remove_all = 5;
hasRemoveAll() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
optional bool remove_all = 5;
hasRemoveAll() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
optional bool remove_all = 5;
hasReplicaId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
optional int32 replica_id = 7 [default = 0];
hasReplicaId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
optional int32 replica_id = 7 [default = 0];
hasReplicaId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
optional int32 replica_id = 7 [default = 0];
hasReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
optional string replicationEndpointImpl = 2;
hasReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
optional string replicationEndpointImpl = 2;
hasReplicationEndpointImpl() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
optional string replicationEndpointImpl = 2;
hasReplicationLag() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
required uint64 replicationLag = 5;
hasReplicationLag() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
required uint64 replicationLag = 5;
hasReplicationLag() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
required uint64 replicationLag = 5;
hasReplLoadSink() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
optional .ReplicationLoadSink replLoadSink = 11;
hasReplLoadSink() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
optional .ReplicationLoadSink replLoadSink = 11;
hasReplLoadSink() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
optional .ReplicationLoadSink replLoadSink = 11;
hasReportEndTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
optional uint64 report_end_time = 8;
hasReportEndTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
optional uint64 report_end_time = 8;
hasReportEndTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
optional uint64 report_end_time = 8;
hasReportStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
optional uint64 report_start_time = 7;
hasReportStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
optional uint64 report_start_time = 7;
hasReportStartTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
optional uint64 report_start_time = 7;
hasReqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
optional .TimedQuota req_num = 1;
hasReqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
optional .TimedQuota req_num = 1;
hasReqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
optional .TimedQuota req_num = 1;
hasReqSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
optional .TimedQuota req_size = 2;
hasReqSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
optional .TimedQuota req_size = 2;
hasReqSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
optional .TimedQuota req_size = 2;
hasRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
required bytes request = 4;
hasRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
required bytes request = 4;
hasRequest() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
required bytes request = 4;
hasRequestParam() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
optional bool request_param = 4;
hasRequestParam() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
optional bool request_param = 4;
hasRequestParam() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
optional bool request_param = 4;
hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
optional int64 requests = 4;
hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
optional int64 requests = 4;
hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int64 requests = 3;
hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
optional int64 requests = 3;
hasRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
optional int64 requests = 3;
hasRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
optional int64 requests = 4;
hasResponse() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse.Builder
required int32 response = 1;
hasResponse() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse
required int32 response = 1;
hasResponse() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponseOrBuilder
required int32 response = 1;
hasResponse() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse.Builder
optional string response = 1;
hasResponse() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse
optional string response = 1;
hasResponse() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponseOrBuilder
optional string response = 1;
hasResponse() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse.Builder
required int32 response = 1;
hasResponse() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse
required int32 response = 1;
hasResponse() - Method in interface org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponseOrBuilder
required int32 response = 1;
hasResponse() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
optional uint32 response = 1;
hasResponse() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
optional uint32 response = 1;
hasResponse() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponseOrBuilder
optional uint32 response = 1;
hasRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string restVersion = 1;
hasRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string restVersion = 1;
hasRestVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string restVersion = 1;
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
optional .Result result = 1;
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
optional .Result result = 1;
hasResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponseOrBuilder
optional .Result result = 1;
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
optional .Result result = 1;
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
optional .Result result = 1;
hasResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponseOrBuilder
optional .Result result = 1;
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
optional .Result result = 2;
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
optional .Result result = 2;
hasResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
optional .Result result = 2;
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
optional bytes result = 4;
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
optional bytes result = 4;
hasResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
optional bytes result = 4;
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
optional bytes result = 11;
hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
optional bytes result = 11;
hasResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
optional bytes result = 11;
hasResultData() - Method in class org.apache.hadoop.hbase.ProcedureInfo
 
hasReturnData() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
optional bytes return_data = 2;
hasReturnData() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
optional bytes return_data = 2;
hasReturnData() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponseOrBuilder
optional bytes return_data = 2;
hasReversed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional bool reversed = 15 [default = false];
hasReversed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional bool reversed = 15 [default = false];
hasReversed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional bool reversed = 15 [default = false];
hasRevision() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
required string revision = 3;
hasRevision() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
required string revision = 3;
hasRevision() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
required string revision = 3;
hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint32 root_index_size_KB = 12;
hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint32 root_index_size_KB = 12;
hasRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint32 root_index_size_KB = 12;
hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 rootIndexSizeKB = 9;
hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 rootIndexSizeKB = 9;
hasRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 rootIndexSizeKB = 9;
hasRow() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
required bytes row = 2;
hasRow() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest
required bytes row = 2;
hasRow() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequestOrBuilder
required bytes row = 2;
hasRow() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest.Builder
required bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest
required bytes row = 1;
hasRow() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequestOrBuilder
required bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest.Builder
required bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest
required bytes row = 1;
hasRow() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequestOrBuilder
required bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
optional bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
optional bytes row = 1;
hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
optional bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
required bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
required bytes row = 1;
hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
required bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
required bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
required bytes row = 1;
hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
required bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
required bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
required bytes row = 1;
hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
required bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
required bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
required bytes row = 1;
hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
required bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
optional bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
optional bytes row = 1;
hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
optional bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional bytes row = 1;
hasRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
optional bytes row = 1;
hasRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
optional bytes row = 1;
hasRow1() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest.Builder
required bytes row1 = 1;
hasRow1() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest
required bytes row1 = 1;
hasRow1() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequestOrBuilder
required bytes row1 = 1;
hasRow2() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest.Builder
required bytes row2 = 2;
hasRow2() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest
required bytes row2 = 2;
hasRow2() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequestOrBuilder
required bytes row2 = 2;
hasRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required uint32 rowBatchSize = 4;
hasRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
required uint32 rowBatchSize = 4;
hasRowBatchSize() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
required uint32 rowBatchSize = 4;
hasRowProcessorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
required string row_processor_class_name = 1;
hasRowProcessorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
required string row_processor_class_name = 1;
hasRowProcessorClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
required string row_processor_class_name = 1;
hasRowProcessorInitializerMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
optional bytes row_processor_initializer_message = 3;
hasRowProcessorInitializerMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
optional bytes row_processor_initializer_message = 3;
hasRowProcessorInitializerMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
optional bytes row_processor_initializer_message = 3;
hasRowProcessorInitializerMessageName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
optional string row_processor_initializer_message_name = 2;
hasRowProcessorInitializerMessageName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
optional string row_processor_initializer_message_name = 2;
hasRowProcessorInitializerMessageName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
optional string row_processor_initializer_message_name = 2;
hasRowProcessorResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
required bytes row_processor_result = 1;
hasRowProcessorResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
required bytes row_processor_result = 1;
hasRowProcessorResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponseOrBuilder
required bytes row_processor_result = 1;
hasRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
required uint64 rowsDeleted = 1;
hasRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
required uint64 rowsDeleted = 1;
hasRowsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
required uint64 rowsDeleted = 1;
hasRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
optional uint32 rpc_version = 2;
hasRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
optional uint32 rpc_version = 2;
hasRpcVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MasterOrBuilder
optional uint32 rpc_version = 2;
hasRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
optional uint32 rpc_version = 2;
hasRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
optional uint32 rpc_version = 2;
hasRpcVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServerOrBuilder
optional uint32 rpc_version = 2;
hasScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
required .Scan scan = 1;
hasScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
required .Scan scan = 1;
hasScan() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
required .Scan scan = 1;
hasScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
required .Scan scan = 2;
hasScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
required .Scan scan = 2;
hasScan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequestOrBuilder
required .Scan scan = 2;
hasScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
optional .Scan scan = 2;
hasScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
optional .Scan scan = 2;
hasScan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
optional .Scan scan = 2;
hasScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
optional uint64 scanner_id = 3;
hasScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
optional uint64 scanner_id = 3;
hasScannerId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
optional uint64 scanner_id = 3;
hasScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
optional uint64 scanner_id = 2;
hasScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
optional uint64 scanner_id = 2;
hasScannerId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
optional uint64 scanner_id = 2;
hasScanResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
optional int32 scan_result = 1;
hasScanResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
optional int32 scan_result = 1;
hasScanResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponseOrBuilder
optional int32 scan_result = 1;
hasScope() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
optional .QuotaScope scope = 4 [default = MACHINE];
hasScope() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
optional .QuotaScope scope = 4 [default = MACHINE];
hasScope() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuotaOrBuilder
optional .QuotaScope scope = 4 [default = MACHINE];
hasScopeType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
required .ScopeType scope_type = 2;
hasScopeType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
required .ScopeType scope_type = 2;
hasScopeType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScopeOrBuilder
required .ScopeType scope_type = 2;
hasSecond() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
required bytes second = 2;
hasSecond() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
required bytes second = 2;
hasSecond() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPairOrBuilder
required bytes second = 2;
hasSecondPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
optional bytes second_part = 2;
hasSecondPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
optional bytes second_part = 2;
hasSecondPart() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponseOrBuilder
optional bytes second_part = 2;
hasSelection() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
 
hasSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
required uint64 sequence_id = 2;
hasSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
required uint64 sequence_id = 2;
hasSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceIdOrBuilder
required uint64 sequence_id = 2;
hasSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
optional int64 sequence_number = 6;
hasSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
optional int64 sequence_number = 6;
hasSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
optional int64 sequence_number = 6;
hasSerializedComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
optional bytes serialized_comparator = 2;
hasSerializedComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
optional bytes serialized_comparator = 2;
hasSerializedComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ComparatorOrBuilder
optional bytes serialized_comparator = 2;
hasSerializedFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
optional bytes serialized_filter = 2;
hasSerializedFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
optional bytes serialized_filter = 2;
hasSerializedFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterOrBuilder
optional bytes serialized_filter = 2;
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
required .ServerName server = 1;
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
required .ServerName server = 1;
hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
required .ServerName server = 1;
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
required .ServerName server = 1;
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
required .ServerName server = 1;
hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
required .ServerName server = 1;
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
required .ServerName server = 1;
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
required .ServerName server = 1;
hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequestOrBuilder
required .ServerName server = 1;
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
required .ServerName server = 1;
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
required .ServerName server = 1;
hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder
required .ServerName server = 1;
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
optional .ServerName server = 6;
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
optional .ServerName server = 6;
hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
optional .ServerName server = 6;
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
required .ServerName server = 1;
hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
required .ServerName server = 1;
hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServerOrBuilder
required .ServerName server = 1;
hasServerCurrentTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
required uint64 server_current_time = 3;
hasServerCurrentTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
required uint64 server_current_time = 3;
hasServerCurrentTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
required uint64 server_current_time = 3;
hasServerInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
required .ServerInfo server_info = 1;
hasServerInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
required .ServerInfo server_info = 1;
hasServerInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponseOrBuilder
required .ServerInfo server_info = 1;
hasServerLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
required .ServerLoad server_load = 2;
hasServerLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
required .ServerLoad server_load = 2;
hasServerLoad() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
required .ServerLoad server_load = 2;
hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
required .ServerName server_name = 1;
hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
required .ServerName server_name = 1;
hasServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfoOrBuilder
required .ServerName server_name = 1;
hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
required .ServerName server_name = 4;
hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
required .ServerName server_name = 4;
hasServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
required .ServerName server_name = 4;
hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
required .ServerName server_name = 2;
hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
required .ServerName server_name = 2;
hasServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
required .ServerName server_name = 2;
hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
optional uint64 serverStartCode = 5;
hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
optional uint64 serverStartCode = 5;
hasServerStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
optional uint64 serverStartCode = 5;
hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
optional uint64 serverStartCode = 2;
hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
optional uint64 serverStartCode = 2;
hasServerStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
optional uint64 serverStartCode = 2;
hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
required uint64 server_start_code = 2;
hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
required uint64 server_start_code = 2;
hasServerStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
required uint64 server_start_code = 2;
hasServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
optional string serverVersion = 4;
hasServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
optional string serverVersion = 4;
hasServerVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
optional string serverVersion = 4;
hasService() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
optional bytes service = 3;
hasService() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
optional bytes service = 3;
hasService() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
optional bytes service = 3;
hasService() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
optional string service = 4;
hasService() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
optional string service = 4;
hasService() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
optional string service = 4;
hasServiceCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
optional .CoprocessorServiceCall service_call = 4;
hasServiceCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
optional .CoprocessorServiceCall service_call = 4;
hasServiceCall() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
optional .CoprocessorServiceCall service_call = 4;
hasServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
required string service_name = 2;
hasServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
required string service_name = 2;
hasServiceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
required string service_name = 2;
hasServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
optional string service_name = 2;
hasServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
optional string service_name = 2;
hasServiceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
optional string service_name = 2;
hasServiceResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
optional .CoprocessorServiceResult service_result = 4;
hasServiceResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
optional .CoprocessorServiceResult service_result = 4;
hasServiceResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
optional .CoprocessorServiceResult service_result = 4;
hasShare() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
optional float share = 3;
hasShare() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
optional float share = 3;
hasShare() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuotaOrBuilder
optional float share = 3;
hasSignature() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
required string signature = 1;
hasSignature() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
required string signature = 1;
hasSignature() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
required string signature = 1;
hasSingleColumnValueFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
required .SingleColumnValueFilter single_column_value_filter = 1;
hasSingleColumnValueFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
required .SingleColumnValueFilter single_column_value_filter = 1;
hasSingleColumnValueFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilterOrBuilder
required .SingleColumnValueFilter single_column_value_filter = 1;
hasSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
required uint32 sizeOfLogQueue = 3;
hasSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
required uint32 sizeOfLogQueue = 3;
hasSizeOfLogQueue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
required uint32 sizeOfLogQueue = 3;
hasSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
required bool skip_table_state_check = 3;
hasSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
required bool skip_table_state_check = 3;
hasSkipTableStateCheck() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateDataOrBuilder
required bool skip_table_state_check = 3;
hasSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
required bool skip_table_state_check = 3;
hasSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
required bool skip_table_state_check = 3;
hasSkipTableStateCheck() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateDataOrBuilder
required bool skip_table_state_check = 3;
hasSmall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional bool small = 14;
hasSmall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional bool small = 14;
hasSmall() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional bool small = 14;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
required .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
required .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequestOrBuilder
required .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
optional .ProcedureDescription snapshot = 2;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
optional .ProcedureDescription snapshot = 2;
hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponseOrBuilder
optional .ProcedureDescription snapshot = 2;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
optional .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
optional .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequestOrBuilder
optional .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
optional .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
optional .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequestOrBuilder
optional .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
optional .SnapshotDescription snapshot = 2;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
optional .SnapshotDescription snapshot = 2;
hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponseOrBuilder
optional .SnapshotDescription snapshot = 2;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
required .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
required .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequestOrBuilder
required .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
required .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
required .SnapshotDescription snapshot = 1;
hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequestOrBuilder
required .SnapshotDescription snapshot = 1;
hasSoftLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
optional uint64 soft_limit = 2;
hasSoftLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
optional uint64 soft_limit = 2;
hasSoftLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuotaOrBuilder
optional uint64 soft_limit = 2;
hasSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
optional string source = 1;
hasSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
optional string source = 1;
hasSource() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
optional string source = 1;
hasSpec() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
required .RegionSpecifier spec = 1;
hasSpec() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
required .RegionSpecifier spec = 1;
hasSpec() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
required .RegionSpecifier spec = 1;
hasSplit() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
optional bool split = 6;
hasSplit() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
optional bool split = 6;
hasSplit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
optional bool split = 6;
hasSplitkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
required bytes splitkey = 1;
hasSplitkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
required bytes splitkey = 1;
hasSplitkey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.ReferenceOrBuilder
required bytes splitkey = 1;
hasSplitPoint() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
optional bytes split_point = 2;
hasSplitPoint() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
optional bytes split_point = 2;
hasSplitPoint() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequestOrBuilder
optional bytes split_point = 2;
hasSrcChecksum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
required string src_checksum = 6;
hasSrcChecksum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
required string src_checksum = 6;
hasSrcChecksum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
required string src_checksum = 6;
hasStackTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
optional string stack_trace = 2;
hasStackTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
optional string stack_trace = 2;
hasStackTrace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
optional string stack_trace = 2;
hasStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
optional bool stale = 4 [default = false];
hasStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
optional bool stale = 4 [default = false];
hasStale() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
optional bool stale = 4 [default = false];
hasStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
optional bool stale = 6;
hasStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
optional bool stale = 6;
hasStale() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
optional bool stale = 6;
hasStamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
optional uint64 stamp = 3;
hasStamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
optional uint64 stamp = 3;
hasStamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
optional uint64 stamp = 3;
hasStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
optional uint64 start_code = 3;
hasStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
optional uint64 start_code = 3;
hasStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
optional uint64 start_code = 3;
hasStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
optional int64 startCode = 2;
hasStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
optional int64 startCode = 2;
hasStartCode() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
optional int64 startCode = 2;
hasStartDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
required string start_date = 1;
hasStartDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
required string start_date = 1;
hasStartDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUpOrBuilder
required string start_date = 1;
hasStartId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
required uint64 start_id = 1;
hasStartId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
required uint64 start_id = 1;
hasStartId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNodeOrBuilder
required uint64 start_id = 1;
hasStartKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
optional bytes start_key = 3;
hasStartKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
optional bytes start_key = 3;
hasStartKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
optional bytes start_key = 3;
hasStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
optional bytes startKey = 2;
hasStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
optional bytes startKey = 2;
hasStartKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
optional bytes startKey = 2;
hasStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional bytes start_row = 3;
hasStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional bytes start_row = 3;
hasStartRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional bytes start_row = 3;
hasStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
optional bytes start_row = 1;
hasStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
optional bytes start_row = 1;
hasStartRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRangeOrBuilder
optional bytes start_row = 1;
hasStartRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
hasStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional bytes startRow = 1;
hasStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional bytes startRow = 1;
hasStartRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional bytes startRow = 1;
hasStartRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
optional bool start_row_inclusive = 2;
hasStartRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
optional bool start_row_inclusive = 2;
hasStartRowInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRangeOrBuilder
optional bool start_row_inclusive = 2;
hasStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
optional uint64 start_time = 2;
hasStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
optional uint64 start_time = 2;
hasStartTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
optional uint64 start_time = 2;
hasStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
required uint64 start_time = 4;
hasStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
required uint64 start_time = 4;
hasStartTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
required uint64 start_time = 4;
hasStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
optional int64 startTime = 5;
hasStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
optional int64 startTime = 5;
hasStartTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
optional int64 startTime = 5;
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
required .RegionState.State state = 2;
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
required .RegionState.State state = 2;
hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
required .RegionState.State state = 2;
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
required .GetProcedureResultResponse.State state = 1;
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
required .GetProcedureResultResponse.State state = 1;
hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
required .GetProcedureResultResponse.State state = 1;
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
required .ProcedureState state = 6;
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
required .ProcedureState state = 6;
hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
required .ProcedureState state = 6;
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
optional .RegionState.State state = 3;
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
optional .RegionState.State state = 3;
hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServerOrBuilder
optional .RegionState.State state = 3;
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
required .ReplicationState.State state = 1;
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
required .ReplicationState.State state = 1;
hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationStateOrBuilder
required .ReplicationState.State state = 1;
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
required .SplitLogTask.State state = 1;
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
required .SplitLogTask.State state = 1;
hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
required .SplitLogTask.State state = 1;
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
required .Table.State state = 1 [default = ENABLED];
hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
required .Table.State state = 1 [default = ENABLED];
hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableOrBuilder
required .Table.State state = 1 [default = ENABLED];
hasStateData() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
optional bytes state_data = 12;
hasStateData() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
optional bytes state_data = 12;
hasStateData() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
optional bytes state_data = 12;
hasStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional bytes stop_row = 4;
hasStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional bytes stop_row = 4;
hasStopRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional bytes stop_row = 4;
hasStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
optional bytes stop_row = 3;
hasStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
optional bytes stop_row = 3;
hasStopRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRangeOrBuilder
optional bytes stop_row = 3;
hasStopRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
optional bool stop_row_inclusive = 4;
hasStopRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
optional bool stop_row_inclusive = 4;
hasStopRowInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRangeOrBuilder
optional bool stop_row_inclusive = 4;
hasStopRowKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
optional bytes stop_row_key = 1;
hasStopRowKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
optional bytes stop_row_key = 1;
hasStopRowKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilterOrBuilder
optional bytes stop_row_key = 1;
hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint32 storefile_index_size_MB = 7;
hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint32 storefile_index_size_MB = 7;
hasStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint32 storefile_index_size_MB = 7;
hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefileIndexSizeMB = 6;
hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 storefileIndexSizeMB = 6;
hasStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 storefileIndexSizeMB = 6;
hasStorefiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint32 storefiles = 3;
hasStorefiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint32 storefiles = 3;
hasStorefiles() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint32 storefiles = 3;
hasStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefiles = 3;
hasStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 storefiles = 3;
hasStorefiles() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 storefiles = 3;
hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint32 storefile_size_MB = 5;
hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint32 storefile_size_MB = 5;
hasStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint32 storefile_size_MB = 5;
hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 storefileSizeMB = 4;
hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 storefileSizeMB = 4;
hasStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 storefileSizeMB = 4;
hasStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
required string store_home_dir = 6;
hasStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
required string store_home_dir = 6;
hasStoreHomeDir() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
required string store_home_dir = 6;
hasStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
required string store_home_dir = 2;
hasStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
required string store_home_dir = 2;
hasStoreHomeDir() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptorOrBuilder
required string store_home_dir = 2;
hasStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
required string store_home_dir = 2;
hasStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
required string store_home_dir = 2;
hasStoreHomeDir() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptorOrBuilder
required string store_home_dir = 2;
hasStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
optional uint32 store_limit = 8;
hasStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
optional uint32 store_limit = 8;
hasStoreLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
optional uint32 store_limit = 8;
hasStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional uint32 store_limit = 11;
hasStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional uint32 store_limit = 11;
hasStoreLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional uint32 store_limit = 11;
hasStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
optional uint32 store_offset = 9;
hasStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
optional uint32 store_offset = 9;
hasStoreOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
optional uint32 store_offset = 9;
hasStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional uint32 store_offset = 12;
hasStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional uint32 store_offset = 12;
hasStoreOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional uint32 store_offset = 12;
hasStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint32 stores = 2;
hasStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint32 stores = 2;
hasStores() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint32 stores = 2;
hasStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 stores = 2;
hasStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 stores = 2;
hasStores() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 stores = 2;
hasStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint32 store_uncompressed_size_MB = 4;
hasStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint32 store_uncompressed_size_MB = 4;
hasStoreUncompressedSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint32 store_uncompressed_size_MB = 4;
hasSubstr() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
required string substr = 1;
hasSubstr() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
required string substr = 1;
hasSubstr() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparatorOrBuilder
required string substr = 1;
hasSum() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse.Builder
required int64 sum = 1;
hasSum() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse
required int64 sum = 1;
hasSum() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponseOrBuilder
required int64 sum = 1;
hasSum() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse.Builder
required int64 sum = 1;
hasSum() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse
required int64 sum = 1;
hasSum() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponseOrBuilder
required int64 sum = 1;
hasSum() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse.Builder
optional int64 sum = 1;
hasSum() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse
optional int64 sum = 1;
hasSum() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponseOrBuilder
optional int64 sum = 1;
hasSynchronous() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
optional bool synchronous = 2;
hasSynchronous() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
optional bool synchronous = 2;
hasSynchronous() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequestOrBuilder
optional bool synchronous = 2;
hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
optional string table = 2;
hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
optional string table = 2;
hasTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
optional string table = 2;
hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
optional .TableSchema table = 3;
hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
optional .TableSchema table = 3;
hasTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplitOrBuilder
optional .TableSchema table = 3;
hasTable() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
 
hasTableName() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateData.Builder
required string table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateData
required string table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateDataOrBuilder
required string table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
optional .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
optional .TableName table_name = 2;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequestOrBuilder
optional .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
optional .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
optional .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermissionOrBuilder
optional .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
required .TableName table_name = 2;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
optional .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
optional .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
optional .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
required .TableName table_name = 2;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
required .TableName table_name = 2;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
required .TableName table_name = 2;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateDataOrBuilder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
required .TableName table_name = 2;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateDataOrBuilder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
required .TableName table_name = 2;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateDataOrBuilder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
required .TableName table_name = 2;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
required .TableName table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
optional .TableName table_name = 3;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
optional .TableName table_name = 3;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
optional .TableName table_name = 3;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
required .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequestOrBuilder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
required .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequestOrBuilder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
required .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequestOrBuilder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
required .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequestOrBuilder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
required .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequestOrBuilder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
required .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequestOrBuilder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
required .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequestOrBuilder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
required .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequestOrBuilder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
required .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequestOrBuilder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
optional .TableName table_name = 4;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
optional .TableName table_name = 4;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
optional .TableName table_name = 4;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
required .TableName tableName = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
required .TableName tableName = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequestOrBuilder
required .TableName tableName = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
required .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequestOrBuilder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
required .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
required .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
required bytes table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
required bytes table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
required bytes table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
required bytes table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
required bytes table_name = 2;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
required bytes table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
required bytes table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
required bytes table_name = 2;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
required bytes table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
required bytes table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
required bytes table_name = 2;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
required bytes table_name = 2;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
optional .TableName table_name = 1;
hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
optional .TableName table_name = 1;
hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
optional .TableName table_name = 1;
hasTablePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
optional .TablePermission table_permission = 4;
hasTablePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
optional .TablePermission table_permission = 4;
hasTablePermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
optional .TablePermission table_permission = 4;
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
required .TableSchema table_schema = 2;
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
required .TableSchema table_schema = 2;
hasTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateDataOrBuilder
required .TableSchema table_schema = 2;
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
optional .TableSchema table_schema = 4;
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
optional .TableSchema table_schema = 4;
hasTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
optional .TableSchema table_schema = 4;
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
required .TableSchema table_schema = 1;
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
required .TableSchema table_schema = 1;
hasTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequestOrBuilder
required .TableSchema table_schema = 1;
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
required .TableSchema table_schema = 2;
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
required .TableSchema table_schema = 2;
hasTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequestOrBuilder
required .TableSchema table_schema = 2;
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
required .TableSchema table_schema = 1;
hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
required .TableSchema table_schema = 1;
hasTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifestOrBuilder
required .TableSchema table_schema = 1;
hasTagCompression - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
hasTagCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
hasTagCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
hasTagCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
 
hasTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
optional bytes tags = 7;
hasTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
optional bytes tags = 7;
hasTags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
optional bytes tags = 7;
hasTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
optional bytes tags = 7;
hasTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
optional bytes tags = 7;
hasTags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
optional bytes tags = 7;
hasTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
optional bytes tags = 5;
hasTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
optional bytes tags = 5;
hasTags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
optional bytes tags = 5;
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
optional int64 thread_id = 3;
hasThreadId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
optional int64 thread_id = 3;
hasThreadId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
optional int64 thread_id = 3;
hasThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
optional .ThrottleRequest throttle = 7;
hasThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
optional .ThrottleRequest throttle = 7;
hasThrottle() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
optional .ThrottleRequest throttle = 7;
hasThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
optional .Throttle throttle = 2;
hasThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
optional .Throttle throttle = 2;
hasThrottle() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotasOrBuilder
optional .Throttle throttle = 2;
hasTimedQuota() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
optional .TimedQuota timed_quota = 2;
hasTimedQuota() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
optional .TimedQuota timed_quota = 2;
hasTimedQuota() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequestOrBuilder
optional .TimedQuota timed_quota = 2;
hasTimeout() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
 
hasTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
optional uint32 timeout = 9;
hasTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
optional uint32 timeout = 9;
hasTimeout() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
optional uint32 timeout = 9;
hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
optional .TimeRange time_range = 5;
hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
optional .TimeRange time_range = 5;
hasTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
optional .TimeRange time_range = 5;
hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
optional .TimeRange time_range = 7;
hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
optional .TimeRange time_range = 7;
hasTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
optional .TimeRange time_range = 7;
hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
optional .TimeRange time_range = 6;
hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
optional .TimeRange time_range = 6;
hasTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
optional .TimeRange time_range = 6;
hasTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
optional uint64 timestamp = 3;
hasTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
optional uint64 timestamp = 3;
hasTimestamp() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
optional uint64 timestamp = 3;
hasTimestamp() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
optional uint64 timestamp = 4;
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
optional uint64 timestamp = 4;
hasTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
optional uint64 timestamp = 4;
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
optional uint64 timestamp = 4;
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
optional uint64 timestamp = 4;
hasTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
optional uint64 timestamp = 4;
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
optional uint64 timestamp = 4;
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
optional uint64 timestamp = 3;
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
optional uint64 timestamp = 3;
hasTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
optional uint64 timestamp = 3;
hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
optional uint64 timestamp = 4;
hasTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
optional uint64 timestamp = 4;
hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
optional int64 timestamp = 3;
hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
optional int64 timestamp = 3;
hasTimestamp() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
optional int64 timestamp = 3;
hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
hasTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
required uint64 timeStampOfLastShippedOp = 4;
hasTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
required uint64 timeStampOfLastShippedOp = 4;
hasTimeStampOfLastShippedOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
required uint64 timeStampOfLastShippedOp = 4;
hasTimeStampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
required uint64 timeStampsOfLastAppliedOp = 2;
hasTimeStampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
required uint64 timeStampsOfLastAppliedOp = 2;
hasTimeStampsOfLastAppliedOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSinkOrBuilder
required uint64 timeStampsOfLastAppliedOp = 2;
hasTimeUnit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
required .TimeUnit time_unit = 1;
hasTimeUnit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
required .TimeUnit time_unit = 1;
hasTimeUnit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuotaOrBuilder
required .TimeUnit time_unit = 1;
hasTo() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
optional uint64 to = 2;
hasTo() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
optional uint64 to = 2;
hasTo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRangeOrBuilder
optional uint64 to = 2;
hasToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
optional .Token token = 1;
hasToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
optional .Token token = 1;
hasToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponseOrBuilder
optional .Token token = 1;
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.ClusterStatusProtos.RegionLoad.Builder
optional uint64 total_compacting_KVs = 10;
hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint64 total_compacting_KVs = 10;
hasTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint64 total_compacting_KVs = 10;
hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 totalCompactingKVs = 12;
hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int64 totalCompactingKVs = 12;
hasTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int64 totalCompactingKVs = 12;
hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
optional uint64 total_number_of_requests = 2;
hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
optional uint64 total_number_of_requests = 2;
hasTotalNumberOfRequests() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
optional uint64 total_number_of_requests = 2;
hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasTotalRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
optional uint32 total_regions = 2;
hasTotalRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
optional uint32 total_regions = 2;
hasTotalRegions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponseOrBuilder
optional uint32 total_regions = 2;
hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint32 total_static_bloom_size_KB = 14;
hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint32 total_static_bloom_size_KB = 14;
hasTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint32 total_static_bloom_size_KB = 14;
hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 totalStaticBloomSizeKB = 11;
hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 totalStaticBloomSizeKB = 11;
hasTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 totalStaticBloomSizeKB = 11;
hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint32 total_static_index_size_KB = 13;
hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint32 total_static_index_size_KB = 13;
hasTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint32 total_static_index_size_KB = 13;
hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int32 totalStaticIndexSizeKB = 10;
hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int32 totalStaticIndexSizeKB = 10;
hasTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int32 totalStaticIndexSizeKB = 10;
hasTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
optional uint64 total_uncompressed_bytes = 4;
hasTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
optional uint64 total_uncompressed_bytes = 4;
hasTotalUncompressedBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
optional uint64 total_uncompressed_bytes = 4;
hasTraceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
optional int64 trace_id = 1;
hasTraceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
optional int64 trace_id = 1;
hasTraceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfoOrBuilder
optional int64 trace_id = 1;
hasTraceInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
optional .RPCTInfo trace_info = 2;
hasTraceInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
optional .RPCTInfo trace_info = 2;
hasTraceInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
optional .RPCTInfo trace_info = 2;
hasTrackerPos() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
required uint64 tracker_pos = 2;
hasTrackerPos() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
required uint64 tracker_pos = 2;
hasTrackerPos() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailerOrBuilder
required uint64 tracker_pos = 2;
hasTransitionCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
required .RegionStateTransition.TransitionCode transition_code = 1;
hasTransitionCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
required .RegionStateTransition.TransitionCode transition_code = 1;
hasTransitionCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransitionOrBuilder
required .RegionStateTransition.TransitionCode transition_code = 1;
hasTransitionInZK() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
optional bool transition_in_ZK = 3 [default = true];
hasTransitionInZK() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
optional bool transition_in_ZK = 3 [default = true];
hasTransitionInZK() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
optional bool transition_in_ZK = 3 [default = true];
hasTtl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
optional uint32 ttl = 4;
hasTtl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
optional uint32 ttl = 4;
hasTtl() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
optional uint32 ttl = 4;
hasTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
optional int32 ttl = 3;
hasTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
optional int32 ttl = 3;
hasTtl() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
optional int32 ttl = 3;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
optional .Permission.Type type = 1;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
optional .Permission.Type type = 1;
hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequestOrBuilder
optional .Permission.Type type = 1;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
required .Permission.Type type = 1;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
required .Permission.Type type = 1;
hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
required .Permission.Type type = 1;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
required .RegionSpecifier.RegionSpecifierType type = 1;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
required .RegionSpecifier.RegionSpecifierType type = 1;
hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifierOrBuilder
required .RegionSpecifier.RegionSpecifierType type = 1;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
optional .SnapshotDescription.Type type = 4 [default = FLUSH];
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
optional .SnapshotDescription.Type type = 4 [default = FLUSH];
hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
optional .SnapshotDescription.Type type = 4 [default = FLUSH];
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
required .ProcedureWALEntry.Type type = 1;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
required .ProcedureWALEntry.Type type = 1;
hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntryOrBuilder
required .ProcedureWALEntry.Type type = 1;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
required uint32 type = 2;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
required uint32 type = 2;
hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeaderOrBuilder
required uint32 type = 2;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
optional .ThrottleType type = 1;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
optional .ThrottleType type = 1;
hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequestOrBuilder
optional .ThrottleType type = 1;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
required .SnapshotFileInfo.Type type = 1;
hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
required .SnapshotFileInfo.Type type = 1;
hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
required .SnapshotFileInfo.Type type = 1;
hasUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
optional uint64 uncompressed_data_index_size = 3;
hasUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
optional uint64 uncompressed_data_index_size = 3;
hasUncompressedDataIndexSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
optional uint64 uncompressed_data_index_size = 3;
hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
optional .TableSchema unmodified_table_schema = 4;
hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
optional .TableSchema unmodified_table_schema = 4;
hasUnmodifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
optional .TableSchema unmodified_table_schema = 4;
hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
optional .TableSchema unmodified_table_schema = 4;
hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
optional .TableSchema unmodified_table_schema = 4;
hasUnmodifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
optional .TableSchema unmodified_table_schema = 4;
hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
optional .TableSchema unmodified_table_schema = 4;
hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
optional .TableSchema unmodified_table_schema = 4;
hasUnmodifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
optional .TableSchema unmodified_table_schema = 4;
hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
optional .TableSchema unmodified_table_schema = 2;
hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
optional .TableSchema unmodified_table_schema = 2;
hasUnmodifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
optional .TableSchema unmodified_table_schema = 2;
hasUrl() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
required string url = 2;
hasUrl() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
required string url = 2;
hasUrl() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
required string url = 2;
hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
optional uint32 used_heap_MB = 3;
hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
optional uint32 used_heap_MB = 3;
hasUsedHeapMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
optional uint32 used_heap_MB = 3;
hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
 
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
required bytes user = 1;
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
required bytes user = 1;
hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionOrBuilder
required bytes user = 1;
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
required bytes user = 1;
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
required bytes user = 1;
hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissionsOrBuilder
required bytes user = 1;
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
required string user = 4;
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
required string user = 4;
hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
required string user = 4;
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
required bytes user = 1;
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
required bytes user = 1;
hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequestOrBuilder
required bytes user = 1;
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
required bytes user = 1;
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
required bytes user = 1;
hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponseOrBuilder
required bytes user = 1;
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
required bytes user = 1;
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
required bytes user = 1;
hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequestOrBuilder
required bytes user = 1;
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
required bytes user = 1;
hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
required bytes user = 1;
hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizationsOrBuilder
required bytes user = 1;
hasUserGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
optional string user_group = 2;
hasUserGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
optional string user_group = 2;
hasUserGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
optional string user_group = 2;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
required .UserInformation user_info = 1;
hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
required .UserInformation user_info = 1;
hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateDataOrBuilder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
required .UserInformation user_info = 1;
hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
required .UserInformation user_info = 1;
hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateDataOrBuilder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
required .UserInformation user_info = 1;
hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateDataOrBuilder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
required .UserInformation user_info = 1;
hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateDataOrBuilder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
required .UserInformation user_info = 1;
hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
required .UserInformation user_info = 1;
hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
required .UserInformation user_info = 1;
hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
required .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
optional .UserInformation user_info = 1;
hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
optional .UserInformation user_info = 1;
hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
optional .UserInformation user_info = 1;
hasUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
required bytes username = 2;
hasUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
required bytes username = 2;
hasUsername() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
required bytes username = 2;
hasUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
optional string username = 1;
hasUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
optional string username = 1;
hasUsername() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponseOrBuilder
optional string username = 1;
hasUserName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
optional string user_name = 1;
hasUserName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
optional string user_name = 1;
hasUserName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
optional string user_name = 1;
hasUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
required .UserPermission user_permission = 1;
hasUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
required .UserPermission user_permission = 1;
hasUserPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequestOrBuilder
required .UserPermission user_permission = 1;
hasUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
required .UserPermission user_permission = 1;
hasUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
required .UserPermission user_permission = 1;
hasUserPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequestOrBuilder
required .UserPermission user_permission = 1;
hasUserTimestamp() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
 
hasUseThisHostnameInstead() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
optional string use_this_hostname_instead = 4;
hasUseThisHostnameInstead() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
optional string use_this_hostname_instead = 4;
hasUseThisHostnameInstead() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
optional string use_this_hostname_instead = 4;
hasValue() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse.Builder
required string value = 1;
hasValue() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse
required string value = 1;
hasValue() - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponseOrBuilder
required string value = 1;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
optional bytes value = 6;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
optional bytes value = 6;
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
optional bytes value = 6;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
optional bytes value = 6;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
optional bytes value = 6;
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
optional bytes value = 6;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
required .NameBytesPair value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
required .NameBytesPair value = 2;
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
required .NameBytesPair value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
optional .NameBytesPair value = 1;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
optional .NameBytesPair value = 1;
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResultOrBuilder
optional .NameBytesPair value = 1;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
optional bytes value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
optional bytes value = 2;
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
optional bytes value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
optional bytes value = 1;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
optional bytes value = 1;
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparableOrBuilder
optional bytes value = 1;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
optional bytes value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
optional bytes value = 2;
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPairOrBuilder
optional bytes value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
optional int64 value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
optional int64 value = 2;
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64PairOrBuilder
optional int64 value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
required string value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
required string value = 2;
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPairOrBuilder
required string value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
required bytes value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
required bytes value = 2;
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifierOrBuilder
required bytes value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
required bool value = 1;
hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
required bool value = 1;
hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponseOrBuilder
required bool value = 1;
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
required string value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
required string value = 2;
hasValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
required string value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
required string value = 2;
hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
required string value = 2;
hasValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
required string value = 2;
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
required string version = 1;
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
required string version = 1;
hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContentOrBuilder
required string version = 1;
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
optional int32 version = 5;
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
optional int32 version = 5;
hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
optional int32 version = 5;
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
required uint32 version = 1;
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
required uint32 version = 1;
hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeaderOrBuilder
required uint32 version = 1;
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
required uint32 version = 1;
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
required uint32 version = 1;
hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailerOrBuilder
required uint32 version = 1;
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
required string version = 1;
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
required string version = 1;
hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
required string version = 1;
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
optional int32 version = 1;
hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
optional int32 version = 1;
hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifestOrBuilder
optional int32 version = 1;
hasVersionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
optional .VersionInfo version_info = 5;
hasVersionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
optional .VersionInfo version_info = 5;
hasVersionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
optional .VersionInfo version_info = 5;
hasVersionOfClosingNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
optional uint32 version_of_closing_node = 2;
hasVersionOfClosingNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
optional uint32 version_of_closing_node = 2;
hasVersionOfClosingNode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
optional uint32 version_of_closing_node = 2;
hasVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
optional uint32 version_of_offline_node = 2;
hasVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
optional uint32 version_of_offline_node = 2;
hasVersionOfOfflineNode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
optional uint32 version_of_offline_node = 2;
hasVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
optional uint64 versionsDeleted = 2;
hasVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
optional uint64 versionsDeleted = 2;
hasVersionsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
optional uint64 versionsDeleted = 2;
hasWalName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
optional string wal_name = 5;
hasWalName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
optional string wal_name = 5;
hasWalName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
optional string wal_name = 5;
hasWalServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
optional string wal_server = 4;
hasWalServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
optional string wal_server = 4;
hasWalServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
optional string wal_server = 4;
hasWebuiPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
optional uint32 webui_port = 2;
hasWebuiPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
optional uint32 webui_port = 2;
hasWebuiPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfoOrBuilder
optional uint32 webui_port = 2;
hasWriteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
optional bool write_flush_wal_marker = 3;
hasWriteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
optional bool write_flush_wal_marker = 3;
hasWriteFlushWalMarker() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
optional bool write_flush_wal_marker = 3;
hasWriteNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
optional .TimedQuota write_num = 3;
hasWriteNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
optional .TimedQuota write_num = 3;
hasWriteNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
optional .TimedQuota write_num = 3;
hasWriterClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
optional string writer_cls_name = 4;
hasWriterClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
optional string writer_cls_name = 4;
hasWriterClsName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
optional string writer_cls_name = 4;
hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
optional uint64 write_requests_count = 9;
hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
optional uint64 write_requests_count = 9;
hasWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
optional uint64 write_requests_count = 9;
hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
optional int64 writeRequestsCount = 8;
hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
optional int64 writeRequestsCount = 8;
hasWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
optional int64 writeRequestsCount = 8;
hasWriteSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
optional .TimedQuota write_size = 4;
hasWriteSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
optional .TimedQuota write_size = 4;
hasWriteSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
optional .TimedQuota write_size = 4;
hasWriteTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
required uint64 write_time = 4;
hasWriteTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
required uint64 write_time = 4;
hasWriteTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
required uint64 write_time = 4;
hasWroteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
optional bool wrote_flush_wal_marker = 3;
hasWroteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
optional bool wrote_flush_wal_marker = 3;
hasWroteFlushWalMarker() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponseOrBuilder
optional bool wrote_flush_wal_marker = 3;
hasYetToUpdateRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
optional uint32 yet_to_update_regions = 1;
hasYetToUpdateRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
optional uint32 yet_to_update_regions = 1;
hasYetToUpdateRegions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponseOrBuilder
optional uint32 yet_to_update_regions = 1;
havingSystemAuth(byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
Deprecated.
havingSystemAuth(User) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
havingSystemAuth(byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.ExpAsStringVisibilityLabelServiceImpl
Deprecated.
havingSystemAuth(User) - Method in class org.apache.hadoop.hbase.security.visibility.ExpAsStringVisibilityLabelServiceImpl
 
havingSystemAuth(byte[]) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
havingSystemAuth(User) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
System checks for user auth during admin operations.
Hbase - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase
 
Hbase.append_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.append_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.append_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.append_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.AsyncClient - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.append_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.atomicIncrement_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.checkAndPut_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.compact_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.createTable_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.deleteAll_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.deleteAllRow_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.deleteAllRowTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.deleteAllTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.deleteTable_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.disableTable_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.enableTable_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.Factory - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.get_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getColumnDescriptors_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRegionInfo_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRow_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowOrBefore_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRows_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowsWithColumns_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowsWithColumnsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowWithColumns_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getRowWithColumnsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getTableNames_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getTableRegions_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getVer_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.getVerTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.increment_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.incrementRows_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.isTableEnabled_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.majorCompact_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.mutateRow_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.mutateRows_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.mutateRowsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.mutateRowTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerClose_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerGet_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerGetList_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerOpen_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerOpenTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerOpenWithPrefix_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerOpenWithScan_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerOpenWithStop_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncClient.scannerOpenWithStopTs_call - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.AsyncIface - Interface in org.apache.hadoop.hbase.thrift.generated
 
Hbase.atomicIncrement_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.atomicIncrement_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.atomicIncrement_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.atomicIncrement_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.checkAndPut_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.checkAndPut_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.checkAndPut_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.checkAndPut_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.Client - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Client.Factory - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.compact_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.compact_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.compact_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.compact_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.createTable_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.createTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.createTable_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.createTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAll_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAll_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAll_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAll_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAllRow_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAllRow_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAllRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRowTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAllRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllRowTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAllTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteAllTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteAllTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteTable_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.deleteTable_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.deleteTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.disableTable_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.disableTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.disableTable_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.disableTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.enableTable_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.enableTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.enableTable_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.enableTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.get_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.get_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.get_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.get_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getColumnDescriptors_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getColumnDescriptors_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getColumnDescriptors_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getColumnDescriptors_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRegionInfo_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRegionInfo_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRegionInfo_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRegionInfo_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRow_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRow_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowOrBefore_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowOrBefore_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowOrBefore_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowOrBefore_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRows_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRows_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowsWithColumns_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowsWithColumns_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowsWithColumns_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowsWithColumns_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowsWithColumnsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowsWithColumnsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowsWithColumnsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowsWithColumnsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowWithColumns_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumns_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowWithColumns_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumns_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowWithColumnsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumnsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getRowWithColumnsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getRowWithColumnsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getTableNames_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableNames_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getTableNames_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableNames_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getTableRegions_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableRegions_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getTableRegions_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getTableRegions_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getVer_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVer_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getVer_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVer_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getVerTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVerTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.getVerTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.getVerTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.Iface - Interface in org.apache.hadoop.hbase.thrift.generated
 
Hbase.increment_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.increment_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.increment_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.increment_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.incrementRows_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.incrementRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.incrementRows_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.incrementRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.isTableEnabled_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.isTableEnabled_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.isTableEnabled_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.isTableEnabled_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.majorCompact_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.majorCompact_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.majorCompact_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.majorCompact_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRow_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRow_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRows_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRows_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRowsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRowsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.mutateRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.mutateRowTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.Processor<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.append<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.atomicIncrement<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.checkAndPut<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.compact<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.createTable<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.deleteAll<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.deleteAllRow<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.deleteAllRowTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.deleteAllTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.deleteTable<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.disableTable<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.enableTable<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.get<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getColumnDescriptors<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRegionInfo<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRow<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowOrBefore<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRows<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowsTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowsWithColumns<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowsWithColumnsTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowWithColumns<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getRowWithColumnsTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getTableNames<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getTableRegions<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getVer<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.getVerTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.increment<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.incrementRows<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.isTableEnabled<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.majorCompact<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.mutateRow<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.mutateRows<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.mutateRowsTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.mutateRowTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerClose<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerGet<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerGetList<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerOpen<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerOpenTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerOpenWithPrefix<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerOpenWithScan<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerOpenWithStop<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.Processor.scannerOpenWithStopTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerClose_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerClose_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerClose_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerClose_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerGet_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerGet_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerGet_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerGet_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerGetList_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerGetList_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerGetList_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerGetList_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpen_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpen_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpen_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpen_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithPrefix_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithPrefix_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithPrefix_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithPrefix_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithScan_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithScan_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithScan_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithScan_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithStop_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStop_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithStop_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStop_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithStopTs_args - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStopTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Hbase.scannerOpenWithStopTs_result - Class in org.apache.hadoop.hbase.thrift.generated
 
Hbase.scannerOpenWithStopTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HBASE_AUTH_TOKEN_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
HBASE_AUTH_TOKEN = 0;
HBASE_CELLS_SCANNED_PER_HEARTBEAT_CHECK - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
The number of cells scanned in between timeout checks.
HBASE_CHECKSUM_VERIFICATION - Static variable in class org.apache.hadoop.hbase.HConstants
If this parameter is set to true, then hbase will read data and then verify checksums.
HBASE_CLIENT_CONNECTION_IMPL - Static variable in interface org.apache.hadoop.hbase.client.HConnection
Deprecated.
Key for configuration in Configuration whose value is the class we implement making a new HConnection instance.
HBASE_CLIENT_ENABLE_FAST_FAIL_MODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_CLEANUP_DURATION_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_CLEANUP_MS_DURATION_MS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_INTERCEPTOR_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_MODE_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
Config for enabling/disabling the fast fail mode.
HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CLIENT_INSTANCE_ID - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for unique identifier for this org.apache.hadoop.conf.Configuration instance.
HBASE_CLIENT_IPC_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client IPC pool size
HBASE_CLIENT_IPC_POOL_TYPE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client IPC pool type
HBASE_CLIENT_MAX_PERREGION_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent connections the client will maintain to a single Region.
HBASE_CLIENT_MAX_PERSERVER_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent connections the client will maintain to a single RegionServer.
HBASE_CLIENT_MAX_TOTAL_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of concurrent connections the client will maintain.
HBASE_CLIENT_META_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase client operation timeout, which overrides RPC timeout
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_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for maximum retries, used as maximum for all retryable operations such as fetching of the root region from root region server, getting a cell's value, starting a row update, etc.
HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name to set the default scanner caching for all clients.
HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for maximum number of bytes returned when calling a scanner's next method.
HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
The client scanner timeout period in milliseconds.
HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_CONFIG_READ_ZOOKEEPER_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_COORDINATED_STATE_MANAGER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
Config for pluggable consensus provider
HBASE_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for HBase instance root directory
HBASE_FLUSH_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
 
HBASE_HSTORE_COMPACTION_MAX_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_MAX_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_HIGHER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
 
HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_LOWER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
 
HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_OFFPEAK - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
 
HBASE_HSTORE_COMPACTION_MIN_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_MIN_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_RATIO_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_RATIO_OFFPEAK_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_COMPACTION_THROUGHPUT_TUNE_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
 
HBASE_HSTORE_MIN_LOCALITY_TO_SKIP_MAJOR_COMPACT - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_OFFPEAK_END_HOUR - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HSTORE_OFFPEAK_START_HOUR - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
 
HBASE_HTTP_STATIC_USER - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
 
HBASE_JETTY_LOGS_SERVE_ALIASES - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
Enable/Disable aliases serving from jetty
HBASE_MASTER_LOADBALANCER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
Config for pluggable load balancers
HBASE_MASTER_LOGCLEANER_PLUGINS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_MASTER_NORMALIZER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
Config for pluggable region normalizer
HBASE_META_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for number of versions, kept by meta table.
HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for number of rows that will be fetched when calling next on a scanner if it is not served from memory.
HBASE_META_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for number of versions, kept by meta table.
HBASE_METRICS_SYSTEM_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.BaseSource
 
HBASE_NON_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
Directories that are not HBase table directories
HBASE_NON_USER_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
Directories that are not HBase user table directories
HBASE_NORMALIZER_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
Config for enabling/disabling pluggable region normalizer
HBASE_REGION_SPLIT_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HBASE_REGIONSERVER_LEASE_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
This config option is deprecated. Will be removed at later releases after 0.96.
HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
timeout for short operation RPC
HBASE_RPC_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
timeout for each RPC
HBASE_RS_HEAP_MEMORY_TUNER_CLASS - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
HBASE_RS_HEAP_MEMORY_TUNER_DEFAULT_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
HBASE_RS_HEAP_MEMORY_TUNER_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
HBASE_RS_NONCES_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
Whether nonces are enabled; default is true.
HBASE_SECURITY_AUTHORIZATION_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.User
 
HBASE_SECURITY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.User
 
HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for server pause value, used mostly as value to wait before running a retry of a failed operation.
HBASE_SERVER_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for maximum number of bytes returned when calling a scanner's next method.
HBASE_SNAPSHOT_ENABLED - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Enable or disable snapshot support
HBASE_SPLITLOG_MANAGER_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for SplitLog manager timeout
HBASE_SSL_ENABLED_DEFAULT - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
 
HBASE_SSL_ENABLED_KEY - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
Enable/Disable ssl for http server
HBASE_TEMP_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
Temporary directory used for table creation and deletion
HBASE_TEST_WAIT_FOR_RATIO - Static variable in class org.apache.hadoop.hbase.Waiter
System property name whose value is a scale factor to increase time out values dynamically used in Waiter.sleep(Configuration, long), Waiter.waitFor(Configuration, long, Predicate), Waiter.waitFor(Configuration, long, long, Predicate), and Waiter.waitFor(Configuration, long, long, boolean, Predicate) method

The actual time out value will equal to hbase.test.wait.for.ratio * passed-in timeout

HBASE_THROUGHPUT_CONTROLLER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputControllerFactory
 
HBASE_VERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
HBaseAdmin - Class in org.apache.hadoop.hbase.client
HBaseAdmin is no longer a client API.
HBaseAdmin(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
Constructing HBaseAdmin objects manually has been deprecated. Use Connection.getAdmin() to obtain an instance of Admin instead.
HBaseAdmin.ProcedureFuture<V> - Class in org.apache.hadoop.hbase.client
Future that waits on a procedure result.
HBaseAdmin.ProcedureFuture.WaitForStateCallable - Interface in org.apache.hadoop.hbase.client
 
HBASECLIENT_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for what hbase client implementation to use.
HBaseCluster - Class in org.apache.hadoop.hbase
This class defines methods that can help with managing HBase clusters from unit tests and system tests.
HBaseCluster(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseCluster
Construct an HBaseCluster
hbaseCluster - Variable in class org.apache.hadoop.hbase.MiniHBaseCluster
 
HBaseClusterManager - Class in org.apache.hadoop.hbase
A default cluster manager for HBase.
HBaseClusterManager() - Constructor for class org.apache.hadoop.hbase.HBaseClusterManager
 
HBaseClusterManager.RemoteShell - Class in org.apache.hadoop.hbase
Executes commands over SSH
HBaseCommonTestingUtility - Class in org.apache.hadoop.hbase
Common helpers for testing HBase that do not depend on specific server/etc.
HBaseCommonTestingUtility() - Constructor for class org.apache.hadoop.hbase.HBaseCommonTestingUtility
 
HBaseCommonTestingUtility(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseCommonTestingUtility
 
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
 
hbaseDir - Static variable in class org.apache.hadoop.hbase.wal.TestWALFactory
 
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.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
 
HBaseHandler(Configuration, UserProvider) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
 
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.
HBaseHomePath - Class in org.apache.hadoop.hbase.util
Determines HBase home path from either class or jar directory
HBaseHTraceConfiguration - Class in org.apache.hadoop.hbase.trace
 
HBaseHTraceConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.trace.HBaseHTraceConfiguration
 
HBaseInterClusterReplicationEndpoint - Class in org.apache.hadoop.hbase.replication.regionserver
A ReplicationEndpoint implementation for replicating to another HBase cluster.
HBaseInterClusterReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
 
HBaseInterfaceAudience - Class in org.apache.hadoop.hbase
This class defines constants for different classes of hbase limited private apis
HBaseInterfaceAudience() - Constructor for class org.apache.hadoop.hbase.HBaseInterfaceAudience
 
HBaseIOException - Exception in org.apache.hadoop.hbase
All hbase specific IOExceptions should be subclasses of HBaseIOException
HBaseIOException() - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseIOException(String) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
 
HBaseKerberosUtils - Class in org.apache.hadoop.hbase.security
 
HBaseKerberosUtils() - Constructor for class org.apache.hadoop.hbase.security.HBaseKerberosUtils
 
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
Protobuf type BigDecimalMsg
HBaseProtos.BigDecimalMsg.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type BigDecimalMsg
HBaseProtos.BigDecimalMsgOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.BytesBytesPair - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type BytesBytesPair
HBaseProtos.BytesBytesPair.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type BytesBytesPair
HBaseProtos.BytesBytesPairOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.ColumnFamilySchema - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type ColumnFamilySchema
HBaseProtos.ColumnFamilySchema.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type ColumnFamilySchema
HBaseProtos.ColumnFamilySchemaOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.CompareType - Enum in org.apache.hadoop.hbase.protobuf.generated
Protobuf enum CompareType
HBaseProtos.Coprocessor - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type Coprocessor
HBaseProtos.Coprocessor.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type Coprocessor
HBaseProtos.CoprocessorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.DoubleMsg - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type DoubleMsg
HBaseProtos.DoubleMsg.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type DoubleMsg
HBaseProtos.DoubleMsgOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.EmptyMsg - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type EmptyMsg
HBaseProtos.EmptyMsg.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type EmptyMsg
HBaseProtos.EmptyMsgOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.FavoredNodes - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type FavoredNodes
HBaseProtos.FavoredNodes.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type FavoredNodes
HBaseProtos.FavoredNodesOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.LongMsg - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type LongMsg
HBaseProtos.LongMsg.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type LongMsg
HBaseProtos.LongMsgOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.NameBytesPair - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type NameBytesPair
HBaseProtos.NameBytesPair.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type NameBytesPair
HBaseProtos.NameBytesPairOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.NameInt64Pair - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type NameInt64Pair
HBaseProtos.NameInt64Pair.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type NameInt64Pair
HBaseProtos.NameInt64PairOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.NamespaceDescriptor - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type NamespaceDescriptor
HBaseProtos.NamespaceDescriptor.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type NamespaceDescriptor
HBaseProtos.NamespaceDescriptorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.NameStringPair - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type NameStringPair
HBaseProtos.NameStringPair.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type NameStringPair
HBaseProtos.NameStringPairOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.ProcedureDescription - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type ProcedureDescription
HBaseProtos.ProcedureDescription.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type ProcedureDescription
HBaseProtos.ProcedureDescriptionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.RegionInfo - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type RegionInfo
HBaseProtos.RegionInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type RegionInfo
HBaseProtos.RegionInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.RegionServerInfo - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type RegionServerInfo
HBaseProtos.RegionServerInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type RegionServerInfo
HBaseProtos.RegionServerInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.RegionSpecifier - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type RegionSpecifier
HBaseProtos.RegionSpecifier.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type RegionSpecifier
HBaseProtos.RegionSpecifier.RegionSpecifierType - Enum in org.apache.hadoop.hbase.protobuf.generated
Protobuf enum RegionSpecifier.RegionSpecifierType
HBaseProtos.RegionSpecifierOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.ServerName - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type ServerName
HBaseProtos.ServerName.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type ServerName
HBaseProtos.ServerNameOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.SnapshotDescription - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type SnapshotDescription
HBaseProtos.SnapshotDescription.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type SnapshotDescription
HBaseProtos.SnapshotDescription.Type - Enum in org.apache.hadoop.hbase.protobuf.generated
Protobuf enum SnapshotDescription.Type
HBaseProtos.SnapshotDescriptionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.TableName - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type TableName
HBaseProtos.TableName.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type TableName
HBaseProtos.TableNameOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.TableSchema - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type TableSchema
HBaseProtos.TableSchema.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type TableSchema
HBaseProtos.TableSchemaOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.TimeRange - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type TimeRange
HBaseProtos.TimeRange.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type TimeRange
HBaseProtos.TimeRangeOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseProtos.TimeUnit - Enum in org.apache.hadoop.hbase.protobuf.generated
Protobuf enum TimeUnit
HBaseProtos.UUID - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type UUID
HBaseProtos.UUID.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type UUID
HBaseProtos.UUIDOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HBaseReaderThread(int) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
 
HBaseReaderThreadWithACL(int) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedReaderWithACL.HBaseReaderThreadWithACL
 
HBaseReplicationEndpoint - Class in org.apache.hadoop.hbase.replication
A BaseReplicationEndpoint for replication endpoints whose target cluster is an HBase cluster.
HBaseReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
HBaseReplicationEndpoint.PeerRegionServerListener - Class in org.apache.hadoop.hbase.replication
Tracks changes to the list of region servers in a peer's cluster.
HBaseRESTTestingUtility - Class in org.apache.hadoop.hbase.rest
 
HBaseRESTTestingUtility() - Constructor for class org.apache.hadoop.hbase.rest.HBaseRESTTestingUtility
 
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, <any>, String, boolean) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
Create a HBaseSaslRpcClient for an authentication method
HBaseSaslRpcClient(AuthMethod, <any>, String, boolean, 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.SaslDigestCallbackHandler - Class in org.apache.hadoop.hbase.security
CallbackHandler for SASL DIGEST-MD5 mechanism
HBaseSaslRpcServer.SaslGssCallbackHandler - Class in org.apache.hadoop.hbase.security
CallbackHandler for SASL GSSAPI Kerberos mechanism
HBaseSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
General exception base class for when a snapshot fails
HBaseSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Some exception happened for a snapshot and don't even know the snapshot that it was about
HBaseSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Exception for the given snapshot that has no previous root cause
HBaseSnapshotException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Exception for the given snapshot due to another exception
HBaseSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
Exception when the description of the snapshot cannot be determined, due to some root other root cause
HBaseTestCase - Class in org.apache.hadoop.hbase
Deprecated.
Write junit4 unit tests using HBaseTestingUtility
HBaseTestCase() - Constructor for class org.apache.hadoop.hbase.HBaseTestCase
Deprecated.
constructor
HBaseTestCase(String) - Constructor for class org.apache.hadoop.hbase.HBaseTestCase
Deprecated.
 
HBaseTestCase.ClientScannerIncommon - Class in org.apache.hadoop.hbase
Deprecated.
 
HBaseTestCase.FlushCache - Interface in org.apache.hadoop.hbase
Deprecated.
Implementors can flushcache.
HBaseTestCase.HRegionIncommon - Class in org.apache.hadoop.hbase
Deprecated.
A class that makes a HBaseTestCase.Incommon out of a HRegion
HBaseTestCase.HTableIncommon - Class in org.apache.hadoop.hbase
Deprecated.
A class that makes a HBaseTestCase.Incommon out of a HTable
HBaseTestCase.Incommon - Interface in org.apache.hadoop.hbase
Deprecated.
Interface used by tests so can do common operations against an HTable or an HRegion.
HBaseTestCase.InternalScannerIncommon - Class in org.apache.hadoop.hbase
Deprecated.
 
HBaseTestCase.ScannerIncommon - Interface in org.apache.hadoop.hbase
Deprecated.
 
HBaseTestingUtility - Class in org.apache.hadoop.hbase
Facility for testing HBase.
HBaseTestingUtility() - Constructor for class org.apache.hadoop.hbase.HBaseTestingUtility
 
HBaseTestingUtility(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseTestingUtility
 
HBaseTestingUtility.SeenRowTracker - Class in org.apache.hadoop.hbase
A tracker for tracking and validating table rows generated with HBaseTestingUtility#loadTable(HTable, byte[])
HBaseUpdaterThread(int) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedUpdater.HBaseUpdaterThread
 
HBaseUpdaterThreadWithACL(int) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL
 
HBaseWriterThread(int) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedWriter.HBaseWriterThread
 
HBaseWriterThreadWithACL(int) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL.HBaseWriterThreadWithACL
 
HBaseZeroCopyByteString - Class in com.google.protobuf
Helper class to extract byte arrays from ByteString without copy.
HBCK_CODE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
HBCK special code name used as server name when manipulating ZK nodes
HBCK_CODE_SERVERNAME - Static variable in class org.apache.hadoop.hbase.master.AssignmentManager
 
HBCK_SIDELINEDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used by HBCK to sideline backup data
HbckTestingUtil - Class in org.apache.hadoop.hbase.util.hbck
 
HbckTestingUtil() - Constructor for class org.apache.hadoop.hbase.util.hbck.HbckTestingUtil
 
HColumnDescriptor - Class in org.apache.hadoop.hbase
An HColumnDescriptor contains information about a column family such as the number of versions, compression settings, etc.
HColumnDescriptor() - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-5453). This will be made private in HBase 2.0.0. Used by Writables and Writables are going away.
HColumnDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Construct a column descriptor specifying only the family name The other attributes are defaulted.
HColumnDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Construct a column descriptor specifying only the family name The other attributes are defaulted.
HColumnDescriptor(HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Constructor.
HColumnDescriptor(byte[], int, String, boolean, boolean, int, String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HColumnDescriptor(byte[], int, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HColumnDescriptor(byte[], int, int, KeepDeletedCells, String, boolean, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
As of release 0.96 (HBASE-). This will be removed in HBase 2.0.0. Use HColumnDescriptor.HColumnDescriptor(String) and setters.
HConnectable<T> - Class in org.apache.hadoop.hbase.client
This class makes it convenient for one to execute a command in the context of a HConnection instance based on the given Configuration.
HConnectable(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HConnectable
 
HConnection - Interface in org.apache.hadoop.hbase.client
Deprecated.
HConnectionManager - Class in org.apache.hadoop.hbase.client
Deprecated.
Please use ConnectionFactory instead
HConnectionTestingUtility - Class in org.apache.hadoop.hbase.client
ClusterConnection testing utility.
HConnectionTestingUtility() - Constructor for class org.apache.hadoop.hbase.client.HConnectionTestingUtility
 
HConstants - Class in org.apache.hadoop.hbase
HConstants holds a bunch of HBase-related constants
HConstants.Modify - Enum in org.apache.hadoop.hbase
modifyTable op for replacing the table descriptor
HConstants.OperationStatusCode - Enum in org.apache.hadoop.hbase
Status codes used for return values of bulk operations.
HDFSBlocksDistribution - Class in org.apache.hadoop.hbase
Data structure to describe the distribution of HDFS blocks among hosts.
HDFSBlocksDistribution() - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution
Constructor
HDFSBlocksDistribution.HostAndWeight - Class in org.apache.hadoop.hbase
Stores the hostname and weight for that hostname.
HDFSBlocksDistribution.HostAndWeight.WeightComparator - Class in org.apache.hadoop.hbase
comparator used to sort hosts based on weight
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.
headerSize(boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Maps a minor version to the size of the header.
headMap(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
headSet(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
headSet(Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
headSet(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
 
HEALTH_CHORE_WAKE_FREQ - Static variable in class org.apache.hadoop.hbase.HConstants
 
HEALTH_FAILURE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
The maximum number of health check failures a server can encounter consecutively.
HEALTH_SCRIPT_LOC - Static variable in class org.apache.hadoop.hbase.HConstants
Health script related settings.
HEALTH_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
 
HealthCheckChore - Class in org.apache.hadoop.hbase
The Class HealthCheckChore for running health checker regularly.
HealthCheckChore(int, Stoppable, Configuration) - Constructor for class org.apache.hadoop.hbase.HealthCheckChore
 
healthCheckerTest(String, HealthChecker.HealthCheckerExitStatus) - Method in class org.apache.hadoop.hbase.TestNodeHealthCheckChore
 
heap - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
heap - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
HEAP_OCCUPANCY_HIGH_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HEAP_OCCUPANCY_LOW_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
HeapMemoryManager - Class in org.apache.hadoop.hbase.regionserver
Manages tuning of Heap memory using HeapMemoryTuner.
HeapMemoryManager.TunerContext - Class in org.apache.hadoop.hbase.regionserver
POJO to pass all the relevant information required to do the heap memory tuning.
HeapMemoryManager.TunerResult - Class in org.apache.hadoop.hbase.regionserver
POJO which holds the result of memory tuning done by HeapMemoryTuner implementation.
HeapMemorySizeUtil - Class in org.apache.hadoop.hbase.io.util
 
HeapMemorySizeUtil() - Constructor for class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
 
HeapMemoryTuner - Interface in org.apache.hadoop.hbase.regionserver
Makes the decision regarding proper sizing of the heap memory.
HeapMemStoreLAB - Class in org.apache.hadoop.hbase.regionserver
A memstore-local allocation buffer.
HeapMemStoreLAB() - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
 
HeapMemStoreLAB(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
 
HEAPOCCUPANCY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
 
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.CacheTestUtils.ByteArrayCacheable
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
HeapSize implementation NOTE : The heapsize should be altered as and when new state variable are added
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
Total size of all elements in this queue.
heapSize() - Method in class org.apache.hadoop.hbase.KeyValue
HeapSize implementation We do not count the bytes in the rowCache because it should be empty for a KeyValue in the MemStore.
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Get the entire heap usage for this MemStore not including keys in the snapshot.
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
heapSize - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The precomputed heap size of this entry
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
Returns the pre-computed and "deep" size of the Entry
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
The total memory usage of this map
heapSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
heapSize() - Method in class org.apache.hadoop.hbase.TagRewriteCell
 
heapSize() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer
 
HEAPSIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
 
heapSizeWithoutTags() - Method in class org.apache.hadoop.hbase.KeyValue
Deprecated.
heartbeat(long, int, ServerName) - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
HEARTBEAT_MESSAGE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
 
heartbeatMessage - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
Saves whether or not the most recent response from the server was a heartbeat message.
heartbeatNoDetails(long) - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
hello(com.google.protobuf.RpcController, PingProtos.HelloRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingService.BlockingInterface
 
hello(com.google.protobuf.RpcController, PingProtos.HelloRequest, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingService
rpc hello(.HelloRequest) returns (.HelloResponse);
hello(com.google.protobuf.RpcController, PingProtos.HelloRequest, <any>) - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingService.Interface
rpc hello(.HelloRequest) returns (.HelloResponse);
hello(com.google.protobuf.RpcController, PingProtos.HelloRequest, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingService.Stub
 
hello(RpcController, PingProtos.HelloRequest, <any>) - Method in class org.apache.hadoop.hbase.regionserver.TestServerCustomProtocol.PingHandler
 
hello(RpcController, PingProtos.HelloRequest, <any>) - Method in class org.apache.hadoop.hbase.security.access.TestAccessController.PingCoprocessor
 
HELPER - Variable in class org.apache.hadoop.hbase.ipc.TestRpcMetrics
 
HELPER - Variable in class org.apache.hadoop.hbase.regionserver.TestMetricsRegion
 
HELPER - Static variable in class org.apache.hadoop.hbase.regionserver.TestMetricsRegionServer
 
HexStringSplit() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
 
HFile - Class in org.apache.hadoop.hbase.io.hfile
File format for hbase.
HFile() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile
 
HFile.CachingBlockReader - Interface in org.apache.hadoop.hbase.io.hfile
An abstraction used by the block index.
HFile.FileInfo - Class in org.apache.hadoop.hbase.io.hfile
Metadata for this file.
HFile.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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
 
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.
HFILE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Type
HFILE = 1;
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
 
HFileArchiveTestingUtil - Class in org.apache.hadoop.hbase.util
Test helper for testing archiving of HFiles
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.BufferGrabbingByteArrayOutputStream - Class in org.apache.hadoop.hbase.io.hfile
 
HFILEBLOCK_DUMMY_HEADER - Static variable in class org.apache.hadoop.hbase.HConstants
Just an array of bytes of the right size.
HFILEBLOCK_HEADER_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
The size of a version 2 HFile block header, minor version 1.
HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM - Static variable in class org.apache.hadoop.hbase.HConstants
The size data structures with minor version is 0
HFileBlockDecodingContext - Interface in org.apache.hadoop.hbase.io.encoding
A decoding context that is created by a reader's encoder, and is shared across the reader's all read operations.
HFileBlockDefaultDecodingContext - Class in org.apache.hadoop.hbase.io.encoding
A default implementation of HFileBlockDecodingContext.
HFileBlockDefaultDecodingContext(HFileContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
 
HFileBlockDefaultEncodingContext - Class in org.apache.hadoop.hbase.io.encoding
A default implementation of HFileBlockEncodingContext.
HFileBlockDefaultEncodingContext(DataBlockEncoding, byte[], HFileContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
HFileBlockEncodingContext - Interface in org.apache.hadoop.hbase.io.encoding
An encoding context that is created by a writer's encoder, and is shared across the writer's whole lifetime.
HFileBlockIndex - Class in org.apache.hadoop.hbase.io.hfile
Provides functionality to write (HFileBlockIndex.BlockIndexWriter) and read (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.BlockIndexWriter - Class in org.apache.hadoop.hbase.io.hfile
Writes the block index into the output stream.
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
 
hFileContext - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
 
HFileContext - Class in org.apache.hadoop.hbase.io.hfile
This carries the information on some of the meta data about the HFile.
HFileContext() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContext
 
HFileContext(HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContext
Copy constructor
HFileContext(boolean, boolean, boolean, Compression.Algorithm, boolean, ChecksumType, int, int, DataBlockEncoding, Encryption.Context, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContext
 
HFileContextBuilder - Class in org.apache.hadoop.hbase.io.hfile
A builder that helps in building up the HFileContext
HFileContextBuilder() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
HFileCorruptionChecker - Class in org.apache.hadoop.hbase.util.hbck
This class marches through all of the region's hfiles and verifies that they are all valid files.
HFileCorruptionChecker(Configuration, ExecutorService, boolean) - Constructor for class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
 
HFileDataBlockEncoder - Interface in org.apache.hadoop.hbase.io.hfile
Controls what kind of data block encoding is used.
HFileDataBlockEncoderImpl - Class in org.apache.hadoop.hbase.io.hfile
Do different kinds of data block encoding according to column family options.
HFileDataBlockEncoderImpl(DataBlockEncoding) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
Do data block encoding with specified options.
HFileFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.HFileFilter
 
HFileLink - Class in org.apache.hadoop.hbase.io
HFileLink describes a link to an hfile.
HFileLink(Path, Path, Path) - Constructor for class org.apache.hadoop.hbase.io.HFileLink
Dead simple hfile link constructor
HFileLinkCleaner - Class in org.apache.hadoop.hbase.master.cleaner
HFileLink cleaner that determines if a hfile should be deleted.
HFileLinkCleaner() - Constructor for class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
 
HFileOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
Deprecated.
use HFileOutputFormat2 instead.
HFileOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
Deprecated.
 
HFileOutputFormat2 - Class in org.apache.hadoop.hbase.mapreduce
Writes HFiles.
HFileOutputFormat2() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
HFilePerformanceEvaluation - Class in org.apache.hadoop.hbase
This class runs performance benchmarks for HFile.
HFilePerformanceEvaluation() - Constructor for class org.apache.hadoop.hbase.HFilePerformanceEvaluation
 
HFilePrettyPrinter - Class in org.apache.hadoop.hbase.io.hfile
Implements pretty-printing functionality for HFiles.
HFilePrettyPrinter() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
 
HFilePrettyPrinter(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
 
HFileProtos - Class in org.apache.hadoop.hbase.protobuf.generated
 
HFileProtos.FileInfoProto - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type FileInfoProto
HFileProtos.FileInfoProto.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type FileInfoProto
HFileProtos.FileInfoProtoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
 
HFileProtos.FileTrailerProto - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type FileTrailerProto
HFileProtos.FileTrailerProto.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
Protobuf type FileTrailerProto
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, FSDataInputStreamWrapper, long, CacheConfig, HFileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
Opens a HFile.
HFileReaderV2.AbstractScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
 
HFileReaderV2.EncodedScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
ScannerV2 that operates on encoded data blocks.
HFileReaderV2.ScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
Implementation of HFileScanner interface.
HFileReaderV3 - Class in org.apache.hadoop.hbase.io.hfile
HFile reader for version 3.
HFileReaderV3(Path, FixedFileTrailer, FSDataInputStreamWrapper, long, CacheConfig, HFileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
Opens a HFile.
HFileReaderV3.EncodedScannerV3 - Class in org.apache.hadoop.hbase.io.hfile
ScannerV3 that operates on encoded data blocks.
HFileReaderV3.ScannerV3 - Class in org.apache.hadoop.hbase.io.hfile
Implementation of HFileScanner interface.
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.
HFileTestUtil - Class in org.apache.hadoop.hbase.util
Utility class for HFile-related testing.
HFileTestUtil() - Constructor for class org.apache.hadoop.hbase.util.HFileTestUtil
 
HFileV1Detector - Class in org.apache.hadoop.hbase.util
Tool to detect presence of any HFileV1 in the given directory.
HFileV1Detector() - Constructor for class org.apache.hadoop.hbase.util.HFileV1Detector
 
HFileWriterV2 - Class in org.apache.hadoop.hbase.io.hfile
Writes HFile format version 2.
HFileWriterV2(Configuration, CacheConfig, FileSystem, Path, FSDataOutputStream, KeyValue.KVComparator, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Constructor that takes a path, creates and closes the output stream.
HFileWriterV3 - Class in org.apache.hadoop.hbase.io.hfile
HFile writer for version 3.
HFileWriterV3(Configuration, CacheConfig, FileSystem, Path, FSDataOutputStream, KeyValue.KVComparator, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
Constructor that takes a path, creates and closes the output stream.
hfs - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
The filesystem used for accesing data
HIGH_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
higher(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
 
hint - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
HINT_LOOKAHEAD - Static variable in class org.apache.hadoop.hbase.client.Scan
Deprecated.
without replacement This is now a no-op, SEEKs and SKIPs are optimizated automatically. Will be removed in 2.0+
HIPHEN - Static variable in class org.apache.hadoop.hbase.IntegrationTestIngest
 
hist - Variable in class org.apache.hadoop.hbase.PerformanceEvaluation.RunResult
 
HistoryReport - Class in org.apache.hadoop.hbase.devtools.buildstats
 
HistoryReport() - Constructor for class org.apache.hadoop.hbase.devtools.buildstats.HistoryReport
 
hit(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
hit(boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
HLogInputFormat - Class in org.apache.hadoop.hbase.mapreduce
Deprecated.
HLogInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
Deprecated.
 
HLogKey - Class in org.apache.hadoop.hbase.regionserver.wal
Deprecated.
use WALKey
HLogKey() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
 
HLogKey(byte[], TableName, long, long, UUID) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
 
HLogKey(byte[], TableName) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
 
HLogKey(byte[], TableName, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
 
HLogKey(byte[], TableName, long, long, List<UUID>, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
Create the log key for writing to somewhere.
HLogKey(byte[], TableName, long, List<UUID>, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
Create the log key for writing to somewhere.
HLogKey(byte[], TableName, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
Deprecated.
Create the log key for writing to somewhere.
HLogPrettyPrinter - Class in org.apache.hadoop.hbase.regionserver.wal
Deprecated.
use the "hbase wal" command
HLogPrettyPrinter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
Deprecated.
Basic constructor that simply initializes values to reasonable defaults.
HLogPrettyPrinter(boolean, boolean, long, String, String, boolean, PrintStream) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
Deprecated.
Fully specified constructor.
HMaster - Class in org.apache.hadoop.hbase.master
HMaster is the "master server" for HBase.
HMaster(Configuration, CoordinatedStateManager) - Constructor for class org.apache.hadoop.hbase.master.HMaster
Initializes the HMaster.
HMaster.RedirectServlet - Class in org.apache.hadoop.hbase.master
 
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
 
hMemManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
host - Static variable in class org.apache.hadoop.hbase.thrift.DemoClient
 
host - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
 
HOST_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
 
hostAddress - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
 
HostAndWeight(String, long) - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
Constructor
hostName(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
Set the hostname of the http server.
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
 
HOUR_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HOURS_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeUnit
HOURS = 6;
HQuorumPeer - Class in org.apache.hadoop.hbase.zookeeper
HBase's version of ZooKeeper's QuorumPeer.
HQuorumPeer() - Constructor for class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
 
HRegion - Class in org.apache.hadoop.hbase.regionserver
 
HRegion(Path, WAL, FileSystem, Configuration, HRegionInfo, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
Deprecated.
HRegion(HRegionFileSystem, WAL, Configuration, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
HRegion constructor.
HRegion.FlushResultImpl - Class in org.apache.hadoop.hbase.regionserver
Objects from this class are created when flushing to describe all the different states that that method ends up in.
HRegion.RowLockImpl - Class in org.apache.hadoop.hbase.regionserver
 
HREGION_COLUMNFAMILY_FLUSH_SIZE_LOWER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
 
HREGION_COMPACTIONDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used to construct the name of the compaction directory during compaction
HREGION_EDITS_REPLAY_SKIP_ERRORS - Static variable in class org.apache.hadoop.hbase.HConstants
 
HREGION_LOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Used to construct the name of the log directory for a region server
HREGION_MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key for the max file size after which we split the region
HREGION_MEMSTORE_BLOCK_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
Block updates if memstore has hbase.hregion.memstore.block.multiplier times hbase.hregion.memstore.flush.size bytes.
HREGION_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Conf key for the memstore size at which we flush the memstore
HREGION_OLDLOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Like the previous, but for old logs that are about to be deleted
HREGION_VERSION - Static variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
 
HRegionFileSystem - Class in org.apache.hadoop.hbase.regionserver
View to an on-disk Region.
HRegionIncommon(HRegion) - Constructor for class org.apache.hadoop.hbase.HBaseTestCase.HRegionIncommon
Deprecated.
 
HRegionIncommon(Region) - Constructor for class org.apache.hadoop.hbase.HBaseTestCase.HRegionIncommon
Deprecated.
 
HRegionInfo - Class in org.apache.hadoop.hbase
Information about a region.
HRegionInfo(long, TableName, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
 
HRegionInfo() - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 0.96 (HBASE-5453). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
HRegionInfo(TableName) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
 
HRegionInfo(TableName, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean, long) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(TableName, byte[], byte[], boolean, long, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Construct HRegionInfo with explicit parameters
HRegionInfo(HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
Costruct a copy of another HRegionInfo
HRegionInfo(HRegionInfo, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
 
HRegionLocation - Class in org.apache.hadoop.hbase
Data structure to hold HRegionInfo and the address for the hosting HRegionServer.
HRegionLocation(HRegionInfo, ServerName) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
 
HRegionLocation(HRegionInfo, ServerName, long) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
 
HRegionLocator - Class in org.apache.hadoop.hbase.client
An implementation of RegionLocator.
HRegionLocator(TableName, ClusterConnection) - Constructor for class org.apache.hadoop.hbase.client.HRegionLocator
 
HRegionMetricsWrapperRunnable() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable
 
HRegionPartitioner<K2,V2> - Class in org.apache.hadoop.hbase.mapred
This is used to partition the output keys into groups of keys.
HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapred.HRegionPartitioner
 
HRegionPartitioner<KEY,VALUE> - Class in org.apache.hadoop.hbase.mapreduce
This is used to partition the output keys into groups of keys.
HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
 
HRegionServer - Class in org.apache.hadoop.hbase.regionserver
HRegionServer makes a set of HRegions available to clients.
HRegionServer(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer
Starts a HRegionServer at the default location.
HRegionServer(Configuration, CoordinatedStateManager) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer
Starts a HRegionServer at the default location
HRegionServer.MovedRegionsCleaner - Class in org.apache.hadoop.hbase.regionserver
Creates a Chore thread to clean the moved region cache.
HRegionServerCommandLine - Class in org.apache.hadoop.hbase.regionserver
Class responsible for parsing the command line and starting the RegionServer.
HRegionServerCommandLine(Class<? extends HRegionServer>) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
 
HStore - Class in org.apache.hadoop.hbase.regionserver
A Store holds a column family in a Region.
HStore(HRegion, HColumnDescriptor, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HStore
Constructor
HSTORE_OPEN_AND_CLOSE_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
The max number of threads used for opening and closing stores or store files in parallel
HTable - Class in org.apache.hadoop.hbase.client
An implementation of Table.
HTable(Configuration, String) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(Configuration, byte[]) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(Configuration, TableName) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(TableName, Connection) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Do not use.
HTable(Configuration, byte[], ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(Configuration, TableName, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Constructing HTable objects manually has been deprecated. Please use Connection to instantiate a Table instead.
HTable(byte[], Connection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Do not use, internal ctor.
HTable(TableName, Connection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Deprecated.
Do not use, internal ctor.
HTable(TableName, ClusterConnection, TableConfiguration, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
Creates an object to access a HBase table.
HTable(ClusterConnection, BufferedMutatorParams) - Constructor for class org.apache.hadoop.hbase.client.HTable
For internal testing.
htable1 - Static variable in class org.apache.hadoop.hbase.replication.TestReplicationBase
 
htable2 - Static variable in class org.apache.hadoop.hbase.replication.TestReplicationBase
 
HTableDescriptor - Class in org.apache.hadoop.hbase
HTableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table, -ROOT- or hbase:meta , if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc...
HTableDescriptor(TableName, HColumnDescriptor[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Private constructor used internally creating table descriptors for catalog tables, hbase:meta and -ROOT-.
HTableDescriptor(TableName, HColumnDescriptor[], Map<ImmutableBytesWritable, ImmutableBytesWritable>) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
INTERNAL Private constructor used internally creating table descriptors for catalog tables, hbase:meta and -ROOT-.
HTableDescriptor() - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
As of release 0.96 (HBASE-5453). This will be removed in HBase 2.0.0. Used by Writables and Writables are going away.
HTableDescriptor(TableName) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor specifying a TableName object
HTableDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
HTableDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
HTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
Construct a table descriptor by cloning the descriptor passed as a parameter.
hTableDescriptor - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
 
hTableDescriptor - Variable in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
 
HTableFactory - Class in org.apache.hadoop.hbase.client
HTableFactory() - Constructor for class org.apache.hadoop.hbase.client.HTableFactory
Deprecated.
 
HTableIncommon(Table) - Constructor for class org.apache.hadoop.hbase.HBaseTestCase.HTableIncommon
Deprecated.
 
HTableInterface - Interface in org.apache.hadoop.hbase.client
Deprecated.
use Table instead
HTableInterfaceFactory - Interface in org.apache.hadoop.hbase.client
Deprecated.
in favor of ConnectionFactory and Connection.
HTableMultiplexer - Class in org.apache.hadoop.hbase.client
HTableMultiplexer provides a thread-safe non blocking PUT API across all the tables.
HTableMultiplexer(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer
 
HTableMultiplexer.HTableMultiplexerStatus - Class in org.apache.hadoop.hbase.client
HTableMultiplexerStatus keeps track of the current status of the HTableMultiplexer.
HTableMultiplexerStatus(Map<HRegionLocation, HTableMultiplexer.FlushWorker>) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
 
HTablePool - Class in org.apache.hadoop.hbase.client
Deprecated.
as of 0.98.1. See HConnection.getTable(String).
HTablePool() - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Default Constructor.
HTablePool(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Constructor to set maximum versions and use the specified configuration.
HTablePool(Configuration, int, HTableInterfaceFactory) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Constructor to set maximum versions and use the specified configuration and table factory.
HTablePool(Configuration, int, PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Constructor to set maximum versions and use the specified configuration and pool type.
HTablePool(Configuration, int, HTableInterfaceFactory, PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
Deprecated.
Constructor to set maximum versions and use the specified configuration, table factory and pool type.
HTableUtil - Class in org.apache.hadoop.hbase.client
Deprecated.
since 1.0
HTableUtil() - Constructor for class org.apache.hadoop.hbase.client.HTableUtil
Deprecated.
 
HTableWrapper - Class in org.apache.hadoop.hbase.client
A wrapper for HTable.
htbl - Variable in class org.apache.hadoop.hbase.util.hbck.OfflineMetaRebuildTestCore
 
htd - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
HTestConst - Class in org.apache.hadoop.hbase
Similar to HConstants but for tests.
htestTagsSurviveBulkLoadSplit() - Method in class org.apache.hadoop.hbase.mapreduce.TestLoadIncrementalHFiles
Test that tags survive through a bulk load that needs to split hfiles.
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
 
HtmlContentServlet() - Constructor for class org.apache.hadoop.hbase.http.TestHttpServer.HtmlContentServlet
 
HtmlQuoting - Class in org.apache.hadoop.hbase.http
This class is responsible for quoting HTML characters.
HtmlQuoting() - Constructor for class org.apache.hadoop.hbase.http.HtmlQuoting
 
HttpAuthenticationException - Exception in org.apache.hadoop.hbase.thrift
 
HttpAuthenticationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
 
HttpAuthenticationException(String) - Constructor for exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
 
HttpAuthenticationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
 
HttpConfig - Class in org.apache.hadoop.hbase.http
Statics to get access to Http related configuration.
HttpConfig(Configuration) - Constructor for class org.apache.hadoop.hbase.http.HttpConfig
 
HttpConfig.Policy - Enum in org.apache.hadoop.hbase.http
 
HttpDoAsClient - Class in org.apache.hadoop.hbase.thrift
See the instructions under hbase-examples/README.txt
HttpRequestLog - Class in org.apache.hadoop.hbase.http
RequestLog object for use with Http
HttpRequestLog() - Constructor for class org.apache.hadoop.hbase.http.HttpRequestLog
 
HttpRequestLogAppender - Class in org.apache.hadoop.hbase.http
Log4j Appender adapter for HttpRequestLog
HttpRequestLogAppender() - Constructor for class org.apache.hadoop.hbase.http.HttpRequestLogAppender
 
HttpServer - Class in org.apache.hadoop.hbase.http
Create a Jetty embedded server to answer http requests.
HttpServer(String, String, int, boolean) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer(String, String, int, boolean, Configuration, Connector) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer(String, String, int, boolean, Configuration, String[]) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer(String, String, int, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer(String, String, int, boolean, Configuration, AccessControlList) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer(String, String, int, boolean, Configuration, AccessControlList, Connector) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer(String, String, int, boolean, Configuration, AccessControlList, Connector, String[]) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
Deprecated.
HttpServer.Builder - Class in org.apache.hadoop.hbase.http
Class to construct instances of HTTP server with specific options.
HttpServer.QuotingInputFilter - Class in org.apache.hadoop.hbase.http
A Servlet input filter that quotes all HTML active characters in the parameter names and values.
HttpServer.QuotingInputFilter.RequestQuoter - Class in org.apache.hadoop.hbase.http
 
HttpServer.StackServlet - Class in org.apache.hadoop.hbase.http
A very simple servlet to serve up a text representation of the current stack traces.
HttpServerFunctionalTest - Class in org.apache.hadoop.hbase.http
This is a base class for functional tests of the HttpServer.
HttpServerFunctionalTest() - Constructor for class org.apache.hadoop.hbase.http.HttpServerFunctionalTest
 
HttpServerUtil - Class in org.apache.hadoop.hbase.util
HttpServer utility.
HttpServerUtil() - Constructor for class org.apache.hadoop.hbase.util.HttpServerUtil
 
humanReadableTimestamp(long) - Static method in class org.apache.hadoop.hbase.KeyValue
 
humanSize(double) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
 
humanTimeDiff(long) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
 
HYPHEN - Static variable in class org.apache.hadoop.hbase.IntegrationTestIngestWithACL
 
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 _ 
Skip navigation links
Hortonworks Data Platform 2.4.0