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 _ 

B

B - Static variable in class org.apache.hadoop.hbase.coprocessor.TestRegionObserverInterface
 
BACK_REFERENCES_DIRECTORY_PREFIX - Static variable in class org.apache.hadoop.hbase.io.FileLink
Define the Back-reference directory name prefix: .links-/
BACKOFF_POLICY_CLASS - Static variable in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
 
BackoffPolicy() - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.BackoffPolicy
 
BACKSLASH - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for Backslash
BACKUP_MASTERS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
backupMasterAddressesZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
Seek scanner to the given key first.
backwardSeek(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner at or after the specified Cell, return if peek KeyValue of scanner has the same row with specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous row of specified KeyValue
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
 
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
 
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
BadAuthException - Exception in org.apache.hadoop.hbase.ipc
 
BadAuthException() - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
BadAuthException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
BadAuthException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
BadFormatException(String) - Constructor for exception org.apache.hadoop.hbase.http.conf.ConfServlet.BadFormatException
 
BadTsvLineException(String) - Constructor for exception org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.BadTsvLineException
 
balance(RegionPlan) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
 
balance() - Method in class org.apache.hadoop.hbase.master.HMaster
 
balance(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
balance(RpcController, MasterProtos.BalanceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
balance(com.google.protobuf.RpcController, MasterProtos.BalanceRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
rpc Balance(.BalanceRequest) returns (.BalanceResponse);
balance(com.google.protobuf.RpcController, MasterProtos.BalanceRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
 
balance(com.google.protobuf.RpcController, MasterProtos.BalanceRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
rpc Balance(.BalanceRequest) returns (.BalanceResponse);
balance(com.google.protobuf.RpcController, MasterProtos.BalanceRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
 
BALANCE_CLUSTER - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
 
balanceCluster(Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
 
balanceCluster(long) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
 
balanceCluster(Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
Generate a global load balancing plan according to the specified map of server information to the most loaded regions of each server.
balanceCluster(Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
Given the cluster state this will try and approach an optimal balance.
balanceCluster(Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.TestBaseLoadBalancer.MockBalancer
 
balanceCluster(Map<ServerName, List<HRegionInfo>>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Perform the major balance operation
BalancedQueueRpcExecutor - Class in org.apache.hadoop.hbase.ipc
An RpcExecutor that will balance requests evenly across all its queues, but still remains efficient with a single queue via an inlinable queue balancing mechanism.
BalancedQueueRpcExecutor(String, int, int, int) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
 
BalancedQueueRpcExecutor(String, int, int, int, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
 
BalancedQueueRpcExecutor(String, int, int, Class<? extends BlockingQueue>, Object...) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
 
BalancedQueueRpcExecutor(String, int, int, Configuration, Abortable, Class<? extends BlockingQueue>, Object...) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
 
balanceMasterRegions(Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Balance the regions that should be on master regionserver.
balancer() - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer.
balancer(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer.
balancer() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Invoke the balancer.
balancer(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
BALANCER_ON_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
 
BALANCER_ON_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
 
BALANCER_RAN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
 
BalancerChore - Class in org.apache.hadoop.hbase.master.balancer
Chore that will call HMaster.balanceHMaster.balance() when needed.
BalancerChore(HMaster) - Constructor for class org.apache.hadoop.hbase.master.balancer.BalancerChore
 
BalancerTestBase - Class in org.apache.hadoop.hbase.master.balancer
Class used to be the base of unit tests on load balancers.
BalancerTestBase() - Constructor for class org.apache.hadoop.hbase.master.balancer.BalancerTestBase
 
BalancerTestBase.MockMapping - Class in org.apache.hadoop.hbase.master.balancer
 
balancerZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
balanceSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
barrierAcquiredByMember(String) - Method in class org.apache.hadoop.hbase.procedure.Procedure
Call back triggered by an individual member upon successful local barrier acquisition
barrierReleasedByMember(String, byte[]) - Method in class org.apache.hadoop.hbase.procedure.Procedure
Call back triggered by a individual member upon successful local in-barrier execution and release
Base() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
 
base - Variable in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
Base64 - Class in org.apache.hadoop.hbase.util
Encodes and decodes to and from Base64 notation.
Base64.Base64InputStream - Class in org.apache.hadoop.hbase.util
A Base64.Base64InputStream will read data from another InputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
Base64.Base64OutputStream - Class in org.apache.hadoop.hbase.util
A Base64.Base64OutputStream will write data to another OutputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
Base64InputStream(InputStream) - Constructor for class org.apache.hadoop.hbase.util.Base64.Base64InputStream
Constructs a Base64.Base64InputStream in DECODE mode.
Base64InputStream(InputStream, int) - Constructor for class org.apache.hadoop.hbase.util.Base64.Base64InputStream
Constructs a Base64.Base64InputStream in either ENCODE or DECODE mode.
Base64OutputStream(OutputStream) - Constructor for class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Constructs a Base64.Base64OutputStream in ENCODE mode.
Base64OutputStream(OutputStream, int) - Constructor for class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
Constructs a Base64.Base64OutputStream in either ENCODE or DECODE mode.
BASE_NAMESPACE_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
 
BASE_TEST_DIRECTORY_KEY - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
System property key to get base test directory value
BaseConfigurable - Class in org.apache.hadoop.hbase
HBase version of Hadoop's Configured class that doesn't initialize the configuration via BaseConfigurable.setConf(Configuration) in the constructor, but only sets the configuration through the BaseConfigurable.setConf(Configuration) method
BaseConfigurable() - Constructor for class org.apache.hadoop.hbase.BaseConfigurable
 
BaseConstraint - Class in org.apache.hadoop.hbase.constraint
Base class to use when actually implementing a Constraint.
BaseConstraint() - Constructor for class org.apache.hadoop.hbase.constraint.BaseConstraint
 
BaseCoordinatedStateManager - Class in org.apache.hadoop.hbase.coordination
Base class for CoordinatedStateManager implementations.
BaseCoordinatedStateManager() - Constructor for class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
 
BaseDecoder - Class in org.apache.hadoop.hbase.codec
TODO javadoc
BaseDecoder(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.BaseDecoder
 
BaseDecoder.PBIS - Class in org.apache.hadoop.hbase.codec
 
BaseEncoder - Class in org.apache.hadoop.hbase.codec
TODO javadoc
BaseEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.BaseEncoder
 
BaseFileCleanerDelegate - Class in org.apache.hadoop.hbase.master.cleaner
Base class for file cleaners which allows subclasses to implement a simple isFileDeletable method (which used to be the FileCleanerDelegate contract).
BaseFileCleanerDelegate() - Constructor for class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
 
BaseHFileCleanerDelegate - Class in org.apache.hadoop.hbase.master.cleaner
Base class for the hfile cleaning function inside the master.
BaseHFileCleanerDelegate() - Constructor for class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
 
BaseLoadBalancer - Class in org.apache.hadoop.hbase.master.balancer
The base class for load balancers.
BaseLoadBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
BaseLoadBalancer.Cluster - Class in org.apache.hadoop.hbase.master.balancer
An efficient array based implementation similar to ClusterState for keeping the status of the cluster in terms of region assignment and distribution.
BaseLoadBalancer.Cluster.Action - Class in org.apache.hadoop.hbase.master.balancer
An action to move or swap a region
BaseLoadBalancer.Cluster.Action.Type - Enum in org.apache.hadoop.hbase.master.balancer
 
BaseLoadBalancer.Cluster.AssignRegionAction - Class in org.apache.hadoop.hbase.master.balancer
 
BaseLoadBalancer.Cluster.MoveRegionAction - Class in org.apache.hadoop.hbase.master.balancer
 
BaseLoadBalancer.Cluster.SwapRegionsAction - Class in org.apache.hadoop.hbase.master.balancer
 
BaseLogCleanerDelegate - Class in org.apache.hadoop.hbase.master.cleaner
Base class for the log cleaning function inside the master.
BaseLogCleanerDelegate() - Constructor for class org.apache.hadoop.hbase.master.cleaner.BaseLogCleanerDelegate
 
BaseMasterAndRegionObserver - Class in org.apache.hadoop.hbase.coprocessor
 
BaseMasterAndRegionObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
 
BaseMasterObserver - Class in org.apache.hadoop.hbase.coprocessor
 
BaseMasterObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
 
BaseRegionObserver - Class in org.apache.hadoop.hbase.coprocessor
An abstract class that implements RegionObserver.
BaseRegionObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
 
BaseRegionServerObserver - Class in org.apache.hadoop.hbase.coprocessor
An abstract class that implements RegionServerObserver.
BaseRegionServerObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
 
BaseReplicationEndpoint - Class in org.apache.hadoop.hbase.replication
A Base implementation for ReplicationEndpoints.
BaseReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
 
BaseRowProcessor<S extends Message,T extends Message> - Class in org.apache.hadoop.hbase.regionserver
Base class for RowProcessor with some default implementations.
BaseRowProcessor() - Constructor for class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
 
BaseRowProcessorEndpoint<S extends Message,T extends Message> - Class in org.apache.hadoop.hbase.coprocessor
This class demonstrates how to implement atomic read-modify-writes using Region.processRowsWithLocks(org.apache.hadoop.hbase.regionserver.RowProcessor<?, ?>) and Coprocessor endpoints.
BaseRowProcessorEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
 
BaseSource - Interface in org.apache.hadoop.hbase.metrics
BaseSource for dynamic metrics to announce to Metrics2.
BaseSourceImpl - Class in org.apache.hadoop.hbase.metrics
Hadoop 2 implementation of BaseSource (using metrics2 framework).
BaseSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
BaseTestRowData - Class in org.apache.hadoop.hbase.codec.prefixtree.row
 
BaseTestRowData() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.row.BaseTestRowData
 
BaseTestStepProcedure() - Constructor for class org.apache.hadoop.hbase.procedure2.TestProcedureRecovery.BaseTestStepProcedure
 
BaseWALEntryFilter - Class in org.apache.hadoop.hbase.replication
A base class WALEntryFilter implementations.
BaseWALEntryFilter() - Constructor for class org.apache.hadoop.hbase.replication.BaseWALEntryFilter
 
BaseWALObserver - Class in org.apache.hadoop.hbase.coprocessor
An abstract class that implements WALObserver.
BaseWALObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
 
baseZNode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
baseZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
 
Batch - Class in org.apache.hadoop.hbase.client.coprocessor
A collection of interfaces and utilities used for interacting with custom RPC interfaces exposed by Coprocessors.
Batch() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.Batch
 
batch(List<? extends Row>, Object[]) - Method in class org.apache.hadoop.hbase.client.HTable
Method that does a batch call on Deletes, Gets, Puts, Increments and Appends.
batch(List<? extends Row>) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use HTable.batch(List, Object[]) instead.
batch(List<? extends Row>, Object[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
batch(List<? extends Row>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use HTableWrapper.batch(List, Object[]) instead.
batch(List<? extends Row>, Object[]) - Method in interface org.apache.hadoop.hbase.client.Table
Method that does a batch call on Deletes, Gets, Puts, Increments and Appends.
batch(List<? extends Row>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use Table.batch(List, Object[]) instead.
batch - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
batch(TableName, Collection<List<Row>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
Do the changes and handle the pool
batch(List<? extends Row>, Object[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batch(List<? extends Row>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
Batch.Call<T,R> - Interface in org.apache.hadoop.hbase.client.coprocessor
Defines a unit of work to be executed.
Batch.Callback<R> - Interface in org.apache.hadoop.hbase.client.coprocessor
Defines a generic callback to be triggered for each Batch.Call.call(Object) result.
BATCH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
 
BATCH_GET_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
BATCH_MUTATE_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
BATCH_RESTART_RS_RATIO - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
 
BATCH_RESTART_RS_SLEEP_TIME - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
 
BATCH_SIZE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
 
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
Same as Table.batch(List, Object[]), but with a callback.
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use HTable.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead.
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use HTableWrapper.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead.
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Same as Table.batch(List, Object[]), but with a callback.
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the partially executed results. Use Table.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead.
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in class org.apache.hadoop.hbase.client.HTable
Creates an instance of the given com.google.protobuf.Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
Creates an instance of the given com.google.protobuf.Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(MethodDescriptor, Message, byte[], byte[], R) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
batchCoprocessorService(MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given com.google.protobuf.Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given com.google.protobuf.Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchMutate(Mutation[], long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchMutate(Mutation[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchMutate(Mutation[], long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Perform a batch of mutations.
BatchMutation - Class in org.apache.hadoop.hbase.thrift.generated
A BatchMutation object is used to apply a number of Mutations to a single row.
BatchMutation() - Constructor for class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
BatchMutation(ByteBuffer, List<Mutation>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
BatchMutation(BatchMutation) - Constructor for class org.apache.hadoop.hbase.thrift.generated.BatchMutation
Performs a deep copy on other.
BatchMutation._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
batchReplay(WALSplitter.MutationReplay[], long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchReplay(WALSplitter.MutationReplay[], long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Replay a batch of mutations.
BatchRestartRsAction - Class in org.apache.hadoop.hbase.chaos.actions
Restarts a ratio of the running regionservers at the same time
BatchRestartRsAction(long, float) - Constructor for class org.apache.hadoop.hbase.chaos.actions.BatchRestartRsAction
 
batchSize - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
 
batchSize - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
bbb - Static variable in class org.apache.hadoop.hbase.client.TestTableSnapshotScanner
 
before() - Method in class org.apache.hadoop.hbase.client.TestMultiParallel
 
before() - Method in class org.apache.hadoop.hbase.client.TestReplicasClient
 
before() - Method in class org.apache.hadoop.hbase.coprocessor.TestHTableWrapper
 
before() - Method in class org.apache.hadoop.hbase.io.TestBoundedByteBufferPool
 
before() - Method in class org.apache.hadoop.hbase.ipc.TestIPCUtil
 
before() - Method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat
 
before() - Method in class org.apache.hadoop.hbase.mapred.TestTableMapReduceUtil
 
before() - Method in class org.apache.hadoop.hbase.mapreduce.TestTableInputFormat
 
before() - Method in class org.apache.hadoop.hbase.mapreduce.TestTimeRangeMapRed
 
before() - Method in class org.apache.hadoop.hbase.master.TestAssignmentManager
 
before() - Method in class org.apache.hadoop.hbase.master.TestClusterStatusPublisher
 
before() - Method in class org.apache.hadoop.hbase.master.TestDistributedLogSplitting
 
before() - Static method in class org.apache.hadoop.hbase.namespace.TestNamespaceAuditor
 
before() - Static method in class org.apache.hadoop.hbase.namespace.TestZKLessNamespaceAuditor
 
before() - Method in class org.apache.hadoop.hbase.quotas.TestQuotaTableUtil
 
before() - Static method in class org.apache.hadoop.hbase.regionserver.handler.TestCloseRegionHandler
 
before() - Static method in class org.apache.hadoop.hbase.regionserver.handler.TestOpenRegionHandler
 
before() - Method in class org.apache.hadoop.hbase.regionserver.TestBulkLoad
 
before() - Method in class org.apache.hadoop.hbase.regionserver.TestRegionReplicaFailover
 
before() - Static method in class org.apache.hadoop.hbase.regionserver.TestRegionReplicas
 
before() - Static method in class org.apache.hadoop.hbase.regionserver.TestRegionServerNoMaster
 
before() - Static method in class org.apache.hadoop.hbase.regionserver.TestRowTooBig
 
before() - Method in class org.apache.hadoop.hbase.regionserver.TestServerCustomProtocol
 
before() - Static method in class org.apache.hadoop.hbase.regionserver.TestSplitTransactionOnCluster
 
before() - Static method in class org.apache.hadoop.hbase.regionserver.TestZKLessSplitOnCluster
 
before() - Method in class org.apache.hadoop.hbase.replication.regionserver.TestRegionReplicaReplicationEndpointNoMaster
 
before() - Method in class org.apache.hadoop.hbase.rest.client.TestRemoteTable
 
before() - Static method in class org.apache.hadoop.hbase.security.TestHBaseSaslRpcClient
 
before() - Method in class org.apache.hadoop.hbase.TestMetaTableAccessorNoCluster
 
before() - Method in class org.apache.hadoop.hbase.TestMetaTableLocator
 
before() - Method in class org.apache.hadoop.hbase.TestMovedRegionsCleaner
 
before() - Method in class org.apache.hadoop.hbase.TestMultiVersions
 
before() - Method in class org.apache.hadoop.hbase.TestRegionRebalancing
 
before() - Static method in class org.apache.hadoop.hbase.trace.TestHTraceHooks
 
beforeAllTests() - Static method in class org.apache.hadoop.hbase.master.balancer.TestBaseLoadBalancer
 
beforeAllTests() - Static method in class org.apache.hadoop.hbase.master.balancer.TestDefaultLoadBalancer
 
beforeAllTests() - Static method in class org.apache.hadoop.hbase.master.balancer.TestStochasticLoadBalancer
 
beforeAllTests() - Static method in class org.apache.hadoop.hbase.master.handler.TestTableDeleteFamilyHandler
Start up a mini cluster and put a small table of empty regions into it.
beforeAllTests() - Static method in class org.apache.hadoop.hbase.master.handler.TestTableDescriptorModification
Start up a mini cluster and put a small table of empty regions into it.
beforeAllTests() - Static method in class org.apache.hadoop.hbase.master.normalizer.TestSimpleRegionNormalizer
 
beforeAllTests() - Static method in class org.apache.hadoop.hbase.master.normalizer.TestSimpleRegionNormalizerOnCluster
 
beforeAllTests() - Static method in class org.apache.hadoop.hbase.master.TestAssignmentListener
 
beforeAllTests() - Static method in class org.apache.hadoop.hbase.master.TestMaster
 
beforeAllTests() - Static method in class org.apache.hadoop.hbase.master.TestMasterTransitions
Start up a mini cluster and put a small table of many empty regions into it.
beforeAllTests() - Static method in class org.apache.hadoop.hbase.master.TestZKBasedOpenCloseRegion
 
beforeAllTests() - Static method in class org.apache.hadoop.hbase.regionserver.TestEndToEndSplitTransaction
 
beforeAllTests() - Static method in class org.apache.hadoop.hbase.regionserver.TestRegionMergeTransactionOnCluster
 
beforeAllTests() - Static method in class org.apache.hadoop.hbase.regionserver.TestZKLessMergeOnCluster
 
beforeAllTests() - Static method in class org.apache.hadoop.hbase.TestHColumnDescriptorDefaultVersions
Start up a mini cluster and put a small table of empty regions into it.
beforeAllTests() - Static method in class org.apache.hadoop.hbase.zookeeper.lock.TestZKInterProcessReadWriteLock
 
beforeClass() - Static method in class org.apache.hadoop.hbase.client.TestAsyncProcess
 
beforeClass() - Static method in class org.apache.hadoop.hbase.client.TestMultiParallel
 
beforeClass() - Static method in class org.apache.hadoop.hbase.client.TestReplicasClient
 
beforeClass() - Static method in class org.apache.hadoop.hbase.client.TestReplicaWithCluster
 
beforeClass() - Static method in class org.apache.hadoop.hbase.io.TestHeapSize
 
beforeClass() - Static method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat
 
beforeClass() - Static method in class org.apache.hadoop.hbase.mapred.TestTableMapReduceUtil
 
beforeClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestCellCounter
 
beforeClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestCopyTable
 
beforeClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestHRegionPartitioner
 
beforeClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestImportExport
 
beforeClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestMultithreadedTableMapper
 
beforeClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestTableInputFormat
 
beforeClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestTableMapReduceBase
 
beforeClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestTimeRangeMapRed
 
beforeClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestWALPlayer
 
beforeClass() - Static method in class org.apache.hadoop.hbase.master.TestAssignmentManager
 
beforeClass() - Static method in class org.apache.hadoop.hbase.regionserver.TestParallelPut
 
beforeClass() - Static method in class org.apache.hadoop.hbase.replication.regionserver.TestRegionReplicaReplicationEndpoint
 
beforeClass() - Static method in class org.apache.hadoop.hbase.replication.regionserver.TestRegionReplicaReplicationEndpointNoMaster
 
beforeClass() - Static method in class org.apache.hadoop.hbase.security.access.TestNamespaceCommands
 
beforeClass() - Static method in class org.apache.hadoop.hbase.security.access.TestTablePermissions
 
beforeClass() - Static method in class org.apache.hadoop.hbase.security.access.TestZKPermissionsWatcher
 
beforeClass() - Static method in class org.apache.hadoop.hbase.TestDrainingServer
 
beforeClass() - Static method in class org.apache.hadoop.hbase.TestInfoServers
 
beforeClass() - Static method in class org.apache.hadoop.hbase.TestMetaTableAccessor
 
beforeClass() - Static method in class org.apache.hadoop.hbase.TestMetaTableLocator
 
beforeClass() - Static method in class org.apache.hadoop.hbase.thrift.TestThriftServer
 
beforeClass() - Static method in class org.apache.hadoop.hbase.thrift2.TestThriftHBaseServiceHandler
 
beforeClass() - Static method in class org.apache.hadoop.hbase.thrift2.TestThriftHBaseServiceHandlerWithLabels
 
beforeExecute() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
Called before compaction is executed by CompactSplitThread; for use by coproc subclasses.
beforeFirst - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
 
beforeGet(long, Get) - Method in class org.apache.hadoop.hbase.security.visibility.LoadTestDataGeneratorWithVisibilityLabels
 
beforeGet(long, Get) - Method in class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
Giving a chance for the LoadTestDataGenerator to change the Get load.
beforeMethod() - Method in class org.apache.hadoop.hbase.rest.RowResourceBase
 
beforeMethod() - Method in class org.apache.hadoop.hbase.TestNamespace
 
beforeMutate(long, Mutation) - Method in class org.apache.hadoop.hbase.security.visibility.LoadTestDataGeneratorWithVisibilityLabels
 
beforeMutate(long, Mutation) - Method in class org.apache.hadoop.hbase.util.LoadTestDataGeneratorWithTags
 
beforeMutate(long, Mutation) - Method in class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
Giving a chance for the LoadTestDataGenerator to change the Mutation load.
beforeMutate(long, Mutation) - Method in class org.apache.hadoop.hbase.util.test.LoadTestDataGeneratorWithACL
 
beforeProcess(EventHandler) - Method in interface org.apache.hadoop.hbase.executor.EventHandler.EventHandlerListener
Called before any event is processed
beforeReplay(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called when the procedure is loaded for replay.
beforeWaitOnSafePoint() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
beginMemstoreInsertWithSeqNum(long) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
This function starts a MVCC transaction with current region's log change sequence number.
beginOp() - Method in class org.apache.hadoop.hbase.util.DrainBarrier
Tries to start an operation.
beginPersistentOutput() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
enables output as a single, persistent list.
benchmarkAlgorithm(Compression.Algorithm, String, byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.DataBlockEncodingTool
Check decompress performance of a given algorithm and print it.
benchmarkCodecs() - Method in class org.apache.hadoop.hbase.regionserver.DataBlockEncodingTool
Benchmark codec's speed.
BIGDECIMAL_MSG_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
 
BigDecimalColumnInterpreter - Class in org.apache.hadoop.hbase.client.coprocessor
ColumnInterpreter for doing Aggregation's with BigDecimal columns.
BigDecimalColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
BinaryComparator - Class in org.apache.hadoop.hbase.filter
A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
BinaryComparator(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryComparator
Constructor
BinaryPrefixComparator - Class in org.apache.hadoop.hbase.filter
A comparator which compares against a specified byte array, but only compares up to the length of this byte array.
BinaryPrefixComparator(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
Constructor
binaryPrefixType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
BinaryPrefixType byte array
binarySearch(Cell[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
 
binarySearch(Cell[], byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Searches for the latest value for the specified column.
binarySearch(byte[][], byte[], int, int, <any>) - Static method in class org.apache.hadoop.hbase.util.Bytes
Binary search for keys in indexes.
binarySearch(byte[][], Cell, <any>) - Static method in class org.apache.hadoop.hbase.util.Bytes
Binary search for keys in indexes.
binaryType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
BinaryType byte array
bind(ServerSocket, InetSocketAddress, int) - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
A convenience method to bind to a given address and report better exceptions if the address is not a valid host.
BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
bindAddress - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
Binomial(Random, int, int, double) - Constructor for class org.apache.hadoop.hbase.io.hfile.RandomDistribution.Binomial
Generate random integers from min (inclusive) to max (exclusive) following Binomial distribution.
BitComparator - Class in org.apache.hadoop.hbase.filter
A bit comparator which performs the specified bitwise operation on each of the bytes with the specified byte array.
BitComparator(byte[], BitComparator.BitwiseOp) - Constructor for class org.apache.hadoop.hbase.filter.BitComparator
Constructor
BitComparator.BitwiseOp - Enum in org.apache.hadoop.hbase.filter
Bit operators.
bitOperator - Variable in class org.apache.hadoop.hbase.filter.BitComparator
 
BitSetNode(long, boolean) - Constructor for class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
BitSetNode(long, long[], long[]) - Constructor for class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
BITWISE_OP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
 
BlackListDirFilter(FileSystem, List<String>) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
Create a filter on the givem filesystem with the specified blacklist
blacklistedRegions - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
 
blobVarEncodedLength(int) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Calculate the expected BlobVar encoded length based on unencoded length.
block - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
 
block - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
fields
block - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
fields
block - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.MvccVersionDecoder
 
block - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.TimestampDecoder
 
block - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
 
block - Variable in class org.apache.hadoop.hbase.codec.prefixtree.row.TestPrefixTreeSearcher
 
block - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
 
BLOCK_CACHE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EVICTION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EVICTION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EXPRESS_HIT_PERCENT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EXPRESS_HIT_PERCENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FREE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FREE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_PERCENT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_PERCENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_EVICTION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_EVICTION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_HIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_SIZE_MAX_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
BLOCK_CACHE_SIZE_MIN_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
BLOCK_COUNT_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_COUNT_PRIMARY_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
BLOCK_START - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.row.TestPrefixTreeSearcher
 
BLOCK_START - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.row.TestRowEncoder
 
blockBuffer - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Key for the BLOCKCACHE attribute.
BlockCache - Interface in org.apache.hadoop.hbase.io.hfile
Block cache interface.
BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.rest.model.TestColumnSchemaModel
 
BLOCKCACHE_BLOCKSIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
The target block size used by blockcache instances.
blockCacheEnabled - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
BlockCacheKey - Class in org.apache.hadoop.hbase.io.hfile
Cache Key for use with implementations of BlockCache
BlockCacheKey(String, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
Construct a new BlockCacheKey
BlockCacheKey(String, long, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
BlockCacheUtil - Class in org.apache.hadoop.hbase.io.hfile
Utilty for aggregating counts in CachedBlocks and toString/toJSON CachedBlocks and BlockCaches.
BlockCacheUtil() - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
 
BlockCacheUtil.CachedBlocksByFile - Class in org.apache.hadoop.hbase.io.hfile
Use one of these to keep a running account of cached blocks by file.
BlockCompactionsInCompletionHStore(HRegion, HColumnDescriptor, Configuration) - Constructor for class org.apache.hadoop.hbase.TestIOFencing.BlockCompactionsInCompletionHStore
 
BlockCompactionsInCompletionRegion(Path, WAL, FileSystem, Configuration, HRegionInfo, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.TestIOFencing.BlockCompactionsInCompletionRegion
 
BlockCompactionsInPrepRegion(Path, WAL, FileSystem, Configuration, HRegionInfo, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.TestIOFencing.BlockCompactionsInPrepRegion
 
BLOCKED_REQUESTS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCKED_REQUESTS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
blockEncoder - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
The data block encoding which will be used.
blockFetches - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
 
BlockIndexNotLoadedException() - Constructor for exception org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.BlockIndexNotLoadedException
 
BlockIndexReader(KeyValue.KVComparator, int, HFile.CachingBlockReader) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
BlockIndexReader(KeyValue.KVComparator, int) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
BlockIndexWriter() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Creates a single-level block index writer
BlockIndexWriter(HFileBlock.Writer, CacheConfig, String) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Creates a multi-level block index writer.
BLOCKING_STOREFILES_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
BlockingCompactionContext() - Constructor for class org.apache.hadoop.hbase.regionserver.TestCompaction.BlockingStoreMockMaker.BlockingCompactionContext
 
BlockingFilter() - Constructor for class org.apache.hadoop.hbase.client.TestHCM.BlockingFilter
 
BlockingRpcCallback<R> - Class in org.apache.hadoop.hbase.ipc
Simple RpcCallback implementation providing a Future-like BlockingRpcCallback.get() method, which will block util the instance's BlockingRpcCallback.run(Object) method has been called.
BlockingRpcCallback() - Constructor for class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
 
BlockingRpcChannelImplementation(AbstractRpcClient, ServerName, User, int) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
 
BlockingServiceAndInterface(BlockingService, Class<?>) - Constructor for class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
 
BlockingStoreMockMaker() - Constructor for class org.apache.hadoop.hbase.regionserver.TestCompaction.BlockingStoreMockMaker
 
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.column.TestColumnBuilder
 
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
fields
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
fields
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
fields
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.MvccVersionDecoder
 
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.TimestampDecoder
 
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
 
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
 
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
 
blockMeta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
 
blockMetaReader - Variable in class org.apache.hadoop.hbase.codec.prefixtree.row.TestRowEncoder
 
blockMetaWriter - Variable in class org.apache.hadoop.hbase.codec.prefixtree.row.TestRowEncoder
 
BlockPriority - Enum in org.apache.hadoop.hbase.io.hfile
 
blockRange(long, long) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
Creates a block iterator over the given portion of the HFile.
blockSeek(Cell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
Within a loaded block, seek looking for the last key that is smaller than (or equal to?) the key we are interested in.
blockSeek(Cell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
Within a loaded block, seek looking for the last key that is smaller than (or equal to?) the key we are interested in.
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Size of storefile/hfile 'blocks'.
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.regionserver.TestHRegionServerBulkLoad
 
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.rest.model.TestColumnSchemaModel
 
blockSizeWritten() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
Returns the number of bytes written into the current block so far, or zero if not writing the block at the moment.
blockSizeWritten() - Method in class org.apache.hadoop.hbase.io.hfile.TestHFileBlockCompatibility.Writer
Returns the number of bytes written into the current block so far, or zero if not writing the block at the moment.
BlockType - Enum in org.apache.hadoop.hbase.io.hfile
Various types of HFile blocks.
BlockType.BlockCategory - Enum in org.apache.hadoop.hbase.io.hfile
 
blockUntilAvailable(ZooKeeperWatcher, long, Configuration) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Wait until the primary meta region is available.
blockUntilAvailable(ZooKeeperWatcher, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Wait until the meta region is available and is not in transition.
blockUntilAvailable(ZooKeeperWatcher, int, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Wait until the meta region is available and is not in transition.
blockUntilAvailable(ZooKeeperWatcher, String, long) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
 
blockUntilAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Gets the data of the node, blocking until the node is available.
blockUntilAvailable(long, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
Gets the data of the node, blocking until the node is available or the specified timeout has elapsed.
blockUntilNoRIT(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Blocks until there are no node in regions in transition.
blockUntilRegionIsInMeta(Connection, long, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.TestEndToEndSplitTransaction
 
blockUntilRegionIsOpened(Configuration, long, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.TestEndToEndSplitTransaction
 
blockUntilRegionSplit(Configuration, long, byte[], boolean) - Static method in class org.apache.hadoop.hbase.regionserver.TestEndToEndSplitTransaction
Blocks until the region split is complete in hbase:meta and region server opens the daughters
blockUntilRIT(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
Blocks until there is at least one node in regions in transition.
BlockWithScanInfo - Class in org.apache.hadoop.hbase.io.hfile
BlockWithScanInfo is wrapper class for HFileBlock with other attributes.
BlockWithScanInfo(HFileBlock, Cell) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
 
blockWritten(long, int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Called after an inline block has been written so that we can add an entry referring to that block to the parent-level index.
blockWritten(long, int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
Called after a block has been written, and its offset, raw size, and compressed size have been determined.
blockWritten(long, int, int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
 
bloom - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Bloom bits
BLOOM_AND_COMPRESSION_COMBINATIONS - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
 
BLOOM_FILTER_DATA_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Meta data block name for bloom filter bits.
BLOOM_FILTER_TYPE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Bloom filter Type in FileInfo
BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.rest.model.TestColumnSchemaModel
 
BloomFilter - Interface in org.apache.hadoop.hbase.util
Defines the general behavior of a bloom filter.
BloomFilterBase - Interface in org.apache.hadoop.hbase.util
Common methods Bloom filter methods required at read and write time.
BloomFilterFactory - Class in org.apache.hadoop.hbase.util
Handles Bloom filter initialization based on configuration and serialized metadata in the reader and writer of StoreFile.
bloomFilterNbHashes - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
bloomFilterType - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
 
bloomFilterType - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
bloomFilterVectorSize - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
BloomFilterWriter - Interface in org.apache.hadoop.hbase.util
Specifies methods needed to add elements to a Bloom filter and serialize the resulting Bloom filter as a sequence of bytes.
BloomType - Enum in org.apache.hadoop.hbase.regionserver
 
bloomType - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
 
BOOLEAN_PARAMETERIZED - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
This is for unit tests parameterized with a two booleans.
BOTTOM_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
BOTTOM = 1;
boundaries - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
BoundaryMultiWriter(List<byte[]>, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
 
BoundaryStripeFlushRequest(List<byte[]>) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequest
 
BoundedArrayQueue<E> - Class in org.apache.hadoop.hbase.util
A bounded non-thread safe implementation of Queue.
BoundedArrayQueue(int) - Constructor for class org.apache.hadoop.hbase.util.BoundedArrayQueue
 
BoundedByteBufferPool - Class in org.apache.hadoop.hbase.io
Like Hadoops' ByteBufferPool only you do not specify desired size when getting a ByteBuffer.
BoundedByteBufferPool(int, int, int) - Constructor for class org.apache.hadoop.hbase.io.BoundedByteBufferPool
 
BoundedCompletionService<V> - Class in org.apache.hadoop.hbase.util
A completion service, close to the one available in the JDK 1.7 However, this ones keeps the list of the future, and allows to cancel them all.
BoundedCompletionService(Executor, int) - Constructor for class org.apache.hadoop.hbase.util.BoundedCompletionService
 
BoundedConcurrentLinkedQueue<T> - Class in org.apache.hadoop.hbase.util
A ConcurrentLinkedQueue that enforces a maximum queue size.
BoundedConcurrentLinkedQueue() - Constructor for class org.apache.hadoop.hbase.util.BoundedConcurrentLinkedQueue
 
BoundedConcurrentLinkedQueue(long) - Constructor for class org.apache.hadoop.hbase.util.BoundedConcurrentLinkedQueue
 
BoundedPriorityBlockingQueue<E> - Class in org.apache.hadoop.hbase.util
A generic bounded blocking Priority-Queue.
BoundedPriorityBlockingQueue(int, Comparator<? super E>) - Constructor for class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
Creates a PriorityQueue with the specified capacity that orders its elements according to the specified comparator.
BoundedRegionGroupingProvider - Class in org.apache.hadoop.hbase.wal
A WAL Provider that pre-creates N WALProviders and then limits our grouping strategy to them.
BoundedRegionGroupingProvider() - Constructor for class org.apache.hadoop.hbase.wal.BoundedRegionGroupingProvider
 
Broken_testSync() - Method in class org.apache.hadoop.hbase.wal.TestWALFactory
Test new HDFS-265 sync.
Bucket(long) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
BUCKET_CACHE_BUCKETS_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
A comma-delimited array of values for use as bucket sizes.
BUCKET_CACHE_COMBINED_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
If the bucket cache is used in league with the lru on-heap block cache (meta blocks such as indices and blooms are kept in the lru blockcache and the data blocks in the bucket cache).
BUCKET_CACHE_IOENGINE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Current ioengine options in include: heap, offheap and file:PATH (where PATH is the path to the file that will host the file-based cache.
BUCKET_CACHE_PERSISTENT_PATH_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
If the chosen ioengine can persist its state across restarts, the path to the file to persist to.
BUCKET_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
When using bucket cache, this is a float that EITHER represents a percentage of total heap memory size to give to the cache (if < 1.0) OR, it is the capacity in megabytes of the cache.
BUCKET_CACHE_WRITER_QUEUE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
BUCKET_CACHE_WRITER_THREADS_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
BucketAllocator - Class in org.apache.hadoop.hbase.io.hfile.bucket
This class is used to allocate a block with specified size and free the block when evicting.
BucketAllocator.Bucket - Class in org.apache.hadoop.hbase.io.hfile.bucket
 
BucketAllocatorException - Exception in org.apache.hadoop.hbase.io.hfile.bucket
Thrown by BucketAllocator
BucketCache - Class in org.apache.hadoop.hbase.io.hfile.bucket
BucketCache uses BucketAllocator to allocate/free blocks, and uses BucketCache.ramCache and BucketCache.backingMap in order to determine if a given element is in the cache.
BucketCache(String, long, int, int[], int, int, String) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
BucketCache(String, long, int, int[], int, int, String, int) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
BucketCacheStats - Class in org.apache.hadoop.hbase.io.hfile.bucket
Class that implements cache metrics for bucket cache.
bucketIndex() - Method in exception org.apache.hadoop.hbase.io.hfile.bucket.CacheFullException
 
bucketRsBatch(HTable, List<Row>) - Static method in class org.apache.hadoop.hbase.client.HTableUtil
Deprecated.
Processes a List of Rows (Put, Delete) and writes them to an HTable instance in RegionServer buckets via the htable.batch method.
bucketRsPut(HTable, List<Put>) - Static method in class org.apache.hadoop.hbase.client.HTableUtil
Deprecated.
Processes a List of Puts and writes them to an HTable instance in RegionServer buckets via the htable.put method.
buf - Variable in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
buffer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.column.TestColumnBuilder
 
buffer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.row.TestRowEncoder
 
BufferedMutator - Interface in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table similar to Table but meant for batched, asynchronous puts.
BufferedMutator.ExceptionListener - Interface in org.apache.hadoop.hbase.client
Listens for asynchronous exceptions on a BufferedMutator.
BufferedMutatorExample - Class in org.apache.hadoop.hbase.client.example
An example of using the BufferedMutator interface.
BufferedMutatorExample() - Constructor for class org.apache.hadoop.hbase.client.example.BufferedMutatorExample
 
BufferedMutatorImpl - Class in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table similar to HTable but meant for batched, potentially asynchronous puts.
BufferedMutatorParams - Class in org.apache.hadoop.hbase.client
Parameters for instantiating a BufferedMutator.
BufferedMutatorParams(TableName) - Constructor for class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
bufferForColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
bufferForColumnName() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
 
bufferForEndKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
bufferForFamily() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
bufferForFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
bufferForFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
bufferForFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
bufferForFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
bufferForFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
bufferForFilterString() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
bufferForFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
bufferForFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
bufferForName() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
 
bufferForName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
bufferForQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
 
bufferForQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
 
bufferForQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
bufferForQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
bufferForQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
 
bufferForRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
 
bufferForServerName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
bufferForStartAndPrefix() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
bufferForStartKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
 
bufferForStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
bufferForStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
bufferForStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
bufferForStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
bufferForStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
bufferForStartRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
bufferForStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
bufferForStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
bufferForStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
 
bufferForStopRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
 
bufferForTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
 
bufferForTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
 
bufferForTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
 
bufferForTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
 
bufferForTags() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
bufferForValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
 
bufferForValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
 
bufferForValue() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
 
bufferForValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
 
bufferForValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
 
bufferForValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
 
BufferGrabbingByteArrayOutputStream() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer.BufferGrabbingByteArrayOutputStream
 
bufferOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
 
BuggyMasterObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.TestMasterCoprocessorExceptionWithAbort.BuggyMasterObserver
 
BuggyMasterObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.TestMasterCoprocessorExceptionWithRemove.BuggyMasterObserver
 
BuggyRegionObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.TestRegionServerCoprocessorExceptionWithAbort.BuggyRegionObserver
 
BuggyRegionObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.TestRegionServerCoprocessorExceptionWithRemove.BuggyRegionObserver
 
build() - Method in class org.apache.hadoop.hbase.chaos.factories.CalmMonkeyFactory
 
build() - Method in class org.apache.hadoop.hbase.chaos.factories.MasterKillingMonkeyFactory
 
build() - Method in class org.apache.hadoop.hbase.chaos.factories.MonkeyFactory
 
build() - Method in class org.apache.hadoop.hbase.chaos.factories.NoKillMonkeyFactory
 
build() - Method in class org.apache.hadoop.hbase.chaos.factories.ServerKillingMonkeyFactory
 
build() - Method in class org.apache.hadoop.hbase.chaos.factories.SlowDeterministicMonkeyFactory
 
build() - Method in class org.apache.hadoop.hbase.chaos.factories.StressAssignmentManagerMonkeyFactory
 
build() - Method in class org.apache.hadoop.hbase.chaos.factories.UnbalanceMonkeyFactory
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
build() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
build(Configuration, TableName, String, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create an HFileLink instance from table/region/family/hfile location
build() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg.Builder
 
build() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateData.Builder
 
build() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProto.Builder
 
build() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto.Builder
 
build() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyRequestProto.Builder
 
build() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyResponseProto.Builder
 
build() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerState.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
build() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
build() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
 
build() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
Create a store file writer.
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
build() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
BUILD_HISTORY_NUM - Static variable in class org.apache.hadoop.hbase.devtools.buildstats.TestResultHistory
 
buildActionResult(Throwable) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Wrap a throwable to an action result.
buildActionResult(ClientProtos.Result, ClientProtos.RegionLoadStats) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Wrap a throwable to an action result.
buildAddColumnRequest(TableName, HColumnDescriptor) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer AddColumnRequest
buildAssignRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer AssignRegionRequest
buildBalanceRequest(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer BalanceRequest
buildBulkLoadHFileRequest(List<Pair<byte[], String>>, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer bulk load request
buildCatalogScanRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for running a catalog scan
buildCellBlock(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
Build cell block
buildCellBlock(Codec, CompressionCodec, CellScanner) - Method in class org.apache.hadoop.hbase.ipc.IPCUtil
Puts CellScanner Cells into a cell block using passed in codec and/or compressor.
buildCellBlock(Codec, CompressionCodec, CellScanner, BoundedByteBufferPool) - Method in class org.apache.hadoop.hbase.ipc.IPCUtil
Puts CellScanner Cells into a cell block using passed in codec and/or compressor.
buildCloseRegionRequest(ServerName, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a CloseRegionRequest for a given region name
buildCloseRegionRequest(ServerName, byte[], int, ServerName, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
 
buildCloseRegionRequest(ServerName, String, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a CloseRegionRequest for a given encoded region name
buildCompactRegionRequest(byte[], boolean, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a CompactRegionRequest for a given region name
buildCreateTableRequest(HTableDescriptor, byte[][]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer CreateTableRequest
buildDeleteColumnRequest(TableName, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer DeleteColumnRequest
buildDeleteTableRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer DeleteTableRequest
buildDependencyClasspath(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Returns a classpath string built from the content of the "tmpjars" value in conf.
buildDisableTableRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer DisableTableRequest
buildDispatchMergingRegionsRequest(byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
 
buildEnableCatalogJanitorRequest(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for enabling/disabling the catalog janitor
buildEnableCatalogJanitorResponse(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the catalog scan request
buildEnableTableRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer EnableTableRequest
builder - Variable in class org.apache.hadoop.hbase.codec.prefixtree.column.TestColumnBuilder
 
builder - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
 
Builder() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.Builder
 
builderNode - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
fields
BuilderStyleTest - Class in org.apache.hadoop.hbase.util
Utility class to check whether a given class conforms to builder-style: Foo foo = new Foo() .setBar(bar) .setBaz(baz)
BuilderStyleTest() - Constructor for class org.apache.hadoop.hbase.util.BuilderStyleTest
 
buildException(Throwable) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
 
buildFilter(String) - Static method in class org.apache.hadoop.hbase.rest.model.ScannerModel
 
buildFilter(String) - Static method in class org.apache.hadoop.hbase.rest.ResultGenerator
 
buildFilterFromModel(ScannerModel) - Static method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
buildFlushRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer FlushRegionRequest for a given region name
buildFlushRegionRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer FlushRegionRequest for a given region name
buildFromHFileLinkPattern(Configuration, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
 
buildFromHFileLinkPattern(Path, Path, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
 
buildGetClusterStatusRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetClusterStatusRequest
buildGetLastFlushedSequenceIdRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for querying the master the last flushed sequence Id for a region
buildGetLastFlushedSequenceIdResponse(ClusterStatusProtos.RegionStoreSequenceIds) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the last flushed sequence Id request
buildGetOnlineRegionRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetOnlineRegionRequest
buildGetOnlineRegionResponse(List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
A utility to build a GetOnlineRegionResponse.
buildGetRegionInfoRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetRegionInfoRequest for a given region name
buildGetRegionInfoRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetRegionInfoRequest for a given region name
buildGetRequest(byte[], Get) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetRequest for a client Get
buildGetRowOrBeforeRequest(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new protocol buffer GetRequest to get a row, all columns in a family.
buildGetSchemaAlterStatusRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetSchemaAlterStatusRequest
buildGetServerInfoRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new GetServerInfoRequest
buildGetServerInfoResponse(ServerName, int) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
A utility to build a GetServerInfoResponse.
buildGetStoreFileRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer GetStoreFileRequest for a given region name
buildGetTableDescriptorsRequest(List<TableName>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest
buildGetTableDescriptorsRequest(Pattern, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest
buildGetTableDescriptorsRequest(TableName) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest for a single table
buildGetTableNamesRequest(Pattern, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer GetTableNamesRequest
buildGetUserPermissionsResponse(List<UserPermission>) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Converts the permissions list into a protocol buffer GetUserPermissionsResponse
buildGrantRequest(String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to grant user permissions.
buildGrantRequest(String, TableName, byte[], byte[], AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to grant user permissions.
buildGrantRequest(String, String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to grant user permissions.
buildHFiles(FileSystem, Path, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TestLoadIncrementalHFilesSplitRecovery
 
buildIncrementRequest(byte[], byte[], byte[], byte[], long, Durability, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a client increment
buildIsBalancerEnabledRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsBalancerEnabledRequest
buildIsCatalogJanitorEnabledRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a request for querying the master whether the catalog janitor is enabled
buildIsMasterRunningRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsMasterRunningRequest
buildIsNormalizerEnabledRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer IsNormalizerEnabledRequest
buildJar(String, String, String) - Static method in class org.apache.hadoop.hbase.util.ClassLoaderTestHelper
Create a test jar for testing purpose for a given class name with specified code string: save the class to a file, compile it, and jar it up.
buildJar(String, String, String, String) - Static method in class org.apache.hadoop.hbase.util.ClassLoaderTestHelper
Create a test jar for testing purpose for a given class name with specified code string.
buildJMXServiceURL(int, int) - Static method in class org.apache.hadoop.hbase.JMXListener
 
buildMergeRegionsRequest(byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a MergeRegionsRequest for the given regions
buildModelFromPut(Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildModifyColumnRequest(TableName, HColumnDescriptor) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ModifyColumnRequest
buildModifyTableRequest(TableName, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer ModifyTableRequest
buildMoveRegionRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MoveRegionRequest
buildMultiRowSpec(byte[][], int) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, Put) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a conditioned put
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, Delete) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a conditioned delete
buildMutateRequest(byte[], byte[], byte[], byte[], ByteArrayComparable, HBaseProtos.CompareType, RowMutations) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for conditioned row mutations
buildMutateRequest(byte[], Put) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a put
buildMutateRequest(byte[], Append, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for an append
buildMutateRequest(byte[], Increment, long, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a client increment
buildMutateRequest(byte[], Delete) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a delete
buildNoDataRegionAction(byte[], RowMutations, List<CellScannable>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MultiRequest for row mutations that does not hold data.
buildNoDataRegionAction(byte[], List<Action<R>>, List<CellScannable>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer multirequest with NO data for a list of actions (data is carried otherwise than via protobuf).
buildNormalizeRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer NormalizeRequest
buildOfflineRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer OfflineRegionRequest
buildOpenRegionRequest(ServerName, List<Triple<HRegionInfo, Integer, List<ServerName>>>, Boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer OpenRegionRequest to open a list of regions
buildOpenRegionRequest(ServerName, HRegionInfo, int, List<ServerName>, Boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer OpenRegionRequest for a given region
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateData.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProto.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyRequestProto.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyResponseProto.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerState.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
 
buildPartial() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
 
buildRegionAction(byte[], RowMutations) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer MultiRequest for row mutations.
buildRegionAction(byte[], List<Action<R>>, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer multi request for a list of actions.
buildRegionSpecifier(HBaseProtos.RegionSpecifier.RegionSpecifierType, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Convert a byte array to a protocol buffer RegionSpecifier
buildReplicateWALEntryRequest(WAL.Entry[]) - Static method in class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
Create a new ReplicateWALEntryRequest from a list of WAL entries
buildReplicateWALEntryRequest(WAL.Entry[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
Create a new ReplicateWALEntryRequest from a list of HLog entries
buildReplicationLoad(List<MetricsSource>, MetricsSink) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
buildReplicationLoad
buildResultFromModel(CellSetModel) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
BuildResultWithTestCaseDetails - Class in org.apache.hadoop.hbase.devtools.buildstats
 
BuildResultWithTestCaseDetails() - Constructor for class org.apache.hadoop.hbase.devtools.buildstats.BuildResultWithTestCaseDetails
 
BuildResultWithTestCaseDetails(List<TestSuite>) - Constructor for class org.apache.hadoop.hbase.devtools.buildstats.BuildResultWithTestCaseDetails
 
BuildResultWithTestCaseDetails(TestSuite...) - Constructor for class org.apache.hadoop.hbase.devtools.buildstats.BuildResultWithTestCaseDetails
 
buildRevokeRequest(String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to revoke user permissions.
buildRevokeRequest(String, TableName, byte[], byte[], AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to revoke user permissions.
buildRevokeRequest(String, String, AccessControlProtos.Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a request to revoke user permissions.
buildRollWALWriterRequest() - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new RollWALWriterRequest
buildRowSpec(byte[], Map, long, long, int) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildRunCatalogScanResponse(int) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
Creates a response for the catalog scan request
buildScanRequest(byte[], Scan, int, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a client Scan
buildScanRequest(long, int, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildScanRequest(long, int, boolean, long) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildSetBalancerRunningRequest(boolean, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer SetBalancerRunningRequest
buildSetNormalizerRunningRequest(boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer SetNormalizerRunningRequest
buildSetQuotaRequestProto(QuotaSettings) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
Convert a QuotaSettings to a protocol buffer SetQuotaRequest.
buildSplitRegionRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a SplitRegionRequest for a given region name
buildStopServerRequest(String) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a new StopServerRequest
buildString(String...) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
 
buildSubprocedure(String) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
If in a running state, creates the specified subprocedure to flush table regions.
buildSubprocedure(String, byte[]) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager.FlushTableSubprocedureBuilder
 
buildSubprocedure(String) - Method in class org.apache.hadoop.hbase.procedure.SimpleRSProcedureManager
If in a running state, creates the specified subprocedure for handling a procedure.
buildSubprocedure(String, byte[]) - Method in class org.apache.hadoop.hbase.procedure.SimpleRSProcedureManager.SimleSubprocedureBuilder
 
buildSubprocedure(String, byte[]) - Method in interface org.apache.hadoop.hbase.procedure.SubprocedureFactory
Build Subprocedure when requested.
buildSubprocedure(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
If in a running state, creates the specified subprocedure for handling an online snapshot.
buildSubprocedure(String, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedureBuilder
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestCellModel
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestCellSetModel
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestColumnSchemaModel
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestModelBase
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestRowModel
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestScannerModel
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestStorageClusterStatusModel
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestStorageClusterVersionModel
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestTableInfoModel
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestTableListModel
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestTableRegionModel
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestTableSchemaModel
 
buildTestModel(String) - Method in class org.apache.hadoop.hbase.rest.model.TestTableSchemaModel
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestVersionModel
 
buildThreadDiagnosticString() - Static method in class org.apache.hadoop.hbase.TimedOutTestsListener
 
buildTruncateTableRequest(TableName, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer TruncateTableRequest
buildUnassignRegionRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Creates a protocol buffer UnassignRegionRequest
buildUpdateFavoredNodesRequest(List<Pair<HRegionInfo, List<ServerName>>>) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings
buildWALHeader(Configuration, WALProtos.WALHeader.Builder) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
buildWALHeader(Configuration, WALProtos.WALHeader.Builder) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogWriter
 
buildWarmupRegionRequest(HRegionInfo) - Static method in class org.apache.hadoop.hbase.protobuf.RequestConverter
Create a WarmupRegionRequest for a given region name
buildZKQuorumServerString(String[], String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
Build the ZK quorum server string with "server:clientport" list, separated by ','
BULK_ASSIGN_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
BULK_LOAD - Static variable in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
 
BULK_OUTPUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
BULK_OUTPUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
BULK_TOKEN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
 
BULK_TOKEN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
 
BULK_TOKEN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
 
bulkAssign() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
 
bulkAssign(boolean) - Method in class org.apache.hadoop.hbase.master.BulkAssigner
Run the bulk assign.
BulkAssigner - Class in org.apache.hadoop.hbase.master
Base class used bulk assigning and unassigning regions.
BulkAssigner(Server) - Constructor for class org.apache.hadoop.hbase.master.BulkAssigner
 
BulkDeleteEndpoint - Class in org.apache.hadoop.hbase.coprocessor.example
Defines a protocol to delete data in bulk based on a scan.
BulkDeleteEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
 
BulkDeleteProtos - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteRequest - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf type BulkDeleteRequest
BulkDeleteProtos.BulkDeleteRequest.Builder - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf type BulkDeleteRequest
BulkDeleteProtos.BulkDeleteRequest.DeleteType - Enum in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf enum BulkDeleteRequest.DeleteType
BulkDeleteProtos.BulkDeleteRequestOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteResponse - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf type BulkDeleteResponse
BulkDeleteProtos.BulkDeleteResponse.Builder - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf type BulkDeleteResponse
BulkDeleteProtos.BulkDeleteResponseOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteService - Class in org.apache.hadoop.hbase.coprocessor.example.generated
Protobuf service BulkDeleteService
BulkDeleteProtos.BulkDeleteService.BlockingInterface - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteService.Interface - Interface in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteProtos.BulkDeleteService.Stub - Class in org.apache.hadoop.hbase.coprocessor.example.generated
 
BulkDeleteService() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
 
bulkHLogShouldThrowErrorWhenFamilySpecifiedAndHFileExistsButNotInTableDescriptor() - Method in class org.apache.hadoop.hbase.regionserver.TestBulkLoad
 
bulkHLogShouldThrowNoErrorAndWriteMarkerWithBlankInput() - Method in class org.apache.hadoop.hbase.regionserver.TestBulkLoad
 
BULKLOAD_SEQ_NUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
 
BULKLOAD_TASK_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
Meta key set when store file is a result of a bulk load
BULKLOAD_TIME_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
 
BulkLoadHelper(Path) - Constructor for class org.apache.hadoop.hbase.security.access.TestAccessController.BulkLoadHelper
 
bulkLoadHFile(com.google.protobuf.RpcController, ClientProtos.BulkLoadHFileRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface
 
bulkLoadHFile(com.google.protobuf.RpcController, ClientProtos.BulkLoadHFileRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
rpc BulkLoadHFile(.BulkLoadHFileRequest) returns (.BulkLoadHFileResponse);
bulkLoadHFile(com.google.protobuf.RpcController, ClientProtos.BulkLoadHFileRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Interface
rpc BulkLoadHFile(.BulkLoadHFileRequest) returns (.BulkLoadHFileResponse);
bulkLoadHFile(com.google.protobuf.RpcController, ClientProtos.BulkLoadHFileRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Stub
 
bulkLoadHFile(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
A helper to bulk load a list of HFiles using client protocol.
bulkLoadHFile(String, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
bulkLoadHFile(StoreFileInfo) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
bulkLoadHFile(RpcController, ClientProtos.BulkLoadHFileRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Atomically bulk load several HFiles into an open region
bulkLoadHFile(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
This method should only be called from Region.
bulkLoadHFile(StoreFileInfo) - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
bulkLoadHFiles(List<Pair<byte[], String>>, <any>, String, byte[]) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
 
bulkLoadHFiles(Collection<Pair<byte[], String>>, boolean, Region.BulkLoadListener) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
bulkLoadHFiles(Collection<Pair<byte[], String>>, boolean, Region.BulkLoadListener) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Attempts to atomically load a group of hfiles.
bulkLoadHFileTest() - Method in class org.apache.hadoop.hbase.coprocessor.TestRegionObserverInterface
 
BulkLoadObserver - Interface in org.apache.hadoop.hbase.coprocessor
Coprocessors implement this interface to observe and mediate bulk load operations.
bulkLoadPhase(Table, Connection, ExecutorService, Deque<LoadIncrementalHFiles.LoadQueueItem>, <any>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
This takes the LQI's grouped by likely regions and attempts to bulk load them.
BulkReOpen - Class in org.apache.hadoop.hbase.master
Performs bulk reopen of the list of regions provided to it.
BulkReOpen(Server, Map<ServerName, List<HRegionInfo>>, AssignmentManager) - Constructor for class org.apache.hadoop.hbase.master.BulkReOpen
 
bulkReOpen() - Method in class org.apache.hadoop.hbase.master.BulkReOpen
 
bypass() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
Call to indicate that the current coprocessor's return value should be used in place of the normal HBase obtained value.
BYPASS_GLOBALS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
 
BYPASS_GLOBALS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
 
bypassGlobals(String, boolean) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Set the "bypass global settings" for the specified user
BYTE_7_RIGHT_BITS_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVIntTool
 
BYTE_7_RIGHT_BITS_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVLongTool
 
BYTE_ARRAY_BASE_OFFSET - Static variable in class org.apache.hadoop.hbase.util.UnsafeAccess
The offset to the first element in a byte array.
BYTE_BUFFER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ByteBuffer
BYTE_BUFFER_HEAP_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
BYTE_LEFT_BIT_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVIntTool
 
BYTE_LEFT_BIT_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVLongTool
 
byteAppender - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
fields
ByteArrayCacheable(byte[]) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheTestUtils.ByteArrayCacheable
 
ByteArrayComparable - Class in org.apache.hadoop.hbase.filter
Base class for byte array comparators
ByteArrayComparable(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ByteArrayComparable
Constructor.
ByteArrayComparator() - Constructor for class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
Constructor
ByteArrayComparator - Class in org.apache.hadoop.hbase.util.comparator
 
ByteArrayComparator() - Constructor for class org.apache.hadoop.hbase.util.comparator.ByteArrayComparator
 
ByteBloomFilter - Class in org.apache.hadoop.hbase.util
Implements a Bloom filter, as defined by Bloom in 1970.
ByteBloomFilter(DataInput) - Constructor for class org.apache.hadoop.hbase.util.ByteBloomFilter
Loads bloom filter meta data from file input.
ByteBloomFilter(int, double, int, int) - Constructor for class org.apache.hadoop.hbase.util.ByteBloomFilter
Determines & initializes bloom filter meta data from user config.
ByteBufferArray - Class in org.apache.hadoop.hbase.util
This class manages an array of ByteBuffers with a default size 4MB.
ByteBufferArray(long, boolean) - Constructor for class org.apache.hadoop.hbase.util.ByteBufferArray
We allocate a number of byte buffers as the capacity.
ByteBufferInputStream - Class in org.apache.hadoop.hbase.io
Not thread safe!
ByteBufferInputStream(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferInputStream
 
ByteBufferIOEngine - Class in org.apache.hadoop.hbase.io.hfile.bucket
IO engine that stores data in memory using an array of ByteBuffers ByteBufferArray
ByteBufferIOEngine(long, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
Construct the ByteBufferIOEngine with the given capacity
ByteBufferOutputStream - Class in org.apache.hadoop.hbase.io
Not thread safe!
ByteBufferOutputStream(int) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteBufferOutputStream(int, boolean) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteBufferOutputStream(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteBufferUtils - Class in org.apache.hadoop.hbase.util
Utility functions for working with byte buffers, such as reading/writing variable-length long numbers.
ByteRange - Interface in org.apache.hadoop.hbase.util
Lightweight, reusable class for specifying ranges of byte[]'s.
ByteRangeHashSet - Class in org.apache.hadoop.hbase.util.byterange.impl
This is probably the best implementation of ByteRangeSet at the moment, though a HashMap produces garbage when adding a new element to it.
ByteRangeHashSet() - Constructor for class org.apache.hadoop.hbase.util.byterange.impl.ByteRangeHashSet
constructors
ByteRangeHashSet(List<ByteRange>) - Constructor for class org.apache.hadoop.hbase.util.byterange.impl.ByteRangeHashSet
 
ByteRangeSet - Class in org.apache.hadoop.hbase.util.byterange
Performance oriented class for de-duping and storing arbitrary byte[]'s arriving in non-sorted order.
ByteRangeSet() - Constructor for class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
construct
ByteRangeTreeSet - Class in org.apache.hadoop.hbase.util.byterange.impl
Not currently used in production, but here as a benchmark comparison against ByteRangeHashSet.
ByteRangeTreeSet() - Constructor for class org.apache.hadoop.hbase.util.byterange.impl.ByteRangeTreeSet
constructors
ByteRangeTreeSet(List<ByteRange>) - Constructor for class org.apache.hadoop.hbase.util.byterange.impl.ByteRangeTreeSet
 
ByteRangeUtils - Class in org.apache.hadoop.hbase.util
Utility methods for working with ByteRange.
ByteRangeUtils() - Constructor for class org.apache.hadoop.hbase.util.ByteRangeUtils
 
bytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.column.TestColumnBuilder
 
bytes - Variable in class org.apache.hadoop.hbase.KeyValue
 
bytes - Variable in class org.apache.hadoop.hbase.util.AbstractByteRange
The array containing the bytes in this range.
Bytes - Class in org.apache.hadoop.hbase.util
Utility class that handles byte arrays, conversions to/from other types, comparisons, hash code generation, manufacturing keys for HashMaps or HashSets, etc.
Bytes() - Constructor for class org.apache.hadoop.hbase.util.Bytes
 
Bytes.ByteArrayComparator - Class in org.apache.hadoop.hbase.util
Byte array comparator class.
Bytes.RowEndKeyComparator - Class in org.apache.hadoop.hbase.util
A Bytes.ByteArrayComparator that treats the empty array as the largest value.
BYTES_COMPARATOR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Pass this to TreeMaps where byte [] are keys.
BYTES_COMPARATOR - Static variable in class org.apache.hadoop.hbase.util.RegionSplitCalculator
 
BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.HConstants
The name of the configuration parameter that specifies the number of bytes in a newly created checksum chunk.
BYTES_RAWCOMPARATOR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Use comparing byte arrays, byte-by-byte
byteSize - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Bytes (B) in the array.
ByteSlot - Class in org.apache.hadoop.hbase.procedure2.util
Similar to the ByteArrayOutputStream, with the exception that we can prepend an header.
ByteSlot() - Constructor for class org.apache.hadoop.hbase.procedure2.util.ByteSlot
 
bytesPerChecksum - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
Bytes per Checksum
bytesPerDelta - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
bytesPerIndex - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
 
bytesToVint(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
ByteStringer - Class in org.apache.hadoop.hbase.util
Hack to workaround HBASE-1304 issue that keeps bubbling up when a mapreduce context.
byteStringUncompressor - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
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