Skip navigation links
Hortonworks Data Platform 3.0.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

BACKUP_ROOT_KEY - Static variable in class org.apache.hadoop.hbase.IntegrationTestBackupRestore
 
backupRoot - Static variable in class org.apache.hadoop.hbase.IntegrationTestBackupRestore
 
backwardSeek(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner at or after the specified Cell, return if peek KeyValue of scanner has the same row with specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous row of specified KeyValue
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
 
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
 
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
 
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner at or after the specified Cell, return if peek KeyValue of scanner has the same row with specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous row of specified KeyValue
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() - Method in class org.apache.hadoop.hbase.master.HMaster
 
balance(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
balance(RpcController, BalanceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
BALANCE_CLUSTER - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
 
balanceCluster(Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
 
balanceCluster(long) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
 
balanceCluster(long) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
 
balanceCluster(Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
Generate a global load balancing plan according to the specified map of server information to the most loaded regions of each server.
balanceCluster(TableName, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
 
balanceCluster(TableName, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
balanceCluster(Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
Given the cluster state this will try and approach an optimal balance.
balanceCluster(TableName, Map<ServerName, List<RegionInfo>>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Perform the major balance operation
balanceCluster(Map<ServerName, List<RegionInfo>>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Perform the major balance operation
balanceCluster(TableName, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
balanceCluster(Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
BalancedQueueRpcExecutor - Class in org.apache.hadoop.hbase.ipc
An RpcExecutor that will balance requests evenly across all its queues, but still remains efficient with a single queue via an inlinable queue balancing mechanism.
BalancedQueueRpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
 
BalancedQueueRpcExecutor(String, int, String, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
 
balanceMasterRegions(Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Balance the regions that should be on master regionserver.
balanceOverall(List<RegionPlan>, Map<ServerName, SimpleLoadBalancer.BalanceInfo>, boolean, <any>, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
If we need to balanceoverall, we need to add one more round to peel off one region from each max.
BalancerChore - Class in org.apache.hadoop.hbase.master.balancer
Chore that will call HMaster.balanceHMaster.balance() when needed.
BalancerChore(HMaster) - Constructor for class org.apache.hadoop.hbase.master.balancer.BalancerChore
 
balanceRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Balance regions in the given RegionServer group.
balanceRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
balanceRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.VerifyingRSGroupAdminClient
 
balanceSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
BASE_WINDOW_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory
 
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
 
BaseFileCleanerDelegate - Class in org.apache.hadoop.hbase.master.cleaner
Base class for file cleaners which allows subclasses to implement a simple isFileDeletable method (which used to be the FileCleanerDelegate contract).
BaseFileCleanerDelegate() - Constructor for class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
 
BaseHFileCleanerDelegate - Class in org.apache.hadoop.hbase.master.cleaner
Base class for the hfile cleaning function inside the master.
BaseHFileCleanerDelegate() - Constructor for class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
 
BaseLoadBalancer - Class in org.apache.hadoop.hbase.master.balancer
The base class for load balancers.
BaseLoadBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
The constructor that uses the basic MetricsBalancer
BaseLoadBalancer(MetricsBalancer) - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
This Constructor accepts an instance of MetricsBalancer, which will be used instead of creating a new one
BaseLoadBalancer.Cluster - Class in org.apache.hadoop.hbase.master.balancer
An efficient array based implementation similar to ClusterState for keeping the status of the cluster in terms of region assignment and distribution.
BaseLoadBalancer.Cluster.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
 
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
 
BaseSource - Interface in org.apache.hadoop.hbase.metrics
BaseSource for dynamic metrics to announce to Metrics2.
BaseWALEntryFilter - Class in org.apache.hadoop.hbase.replication
A base class WALEntryFilter implementations.
BaseWALEntryFilter() - Constructor for class org.apache.hadoop.hbase.replication.BaseWALEntryFilter
 
BasicMemStoreCompactionStrategy - Class in org.apache.hadoop.hbase.regionserver
Basic strategy chooses between two actions: flattening a segment or merging indices of all segments in the pipeline.
BasicMemStoreCompactionStrategy(Configuration, String) - Constructor for class org.apache.hadoop.hbase.regionserver.BasicMemStoreCompactionStrategy
 
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_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
 
batchCallback(List<? extends Row>, Object[], <any>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, <any>) - 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[], boolean, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchMutate(Mutation[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchReplay(MutationReplay[], long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
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
 
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.mapred.TestTableOutputFormatConnectionExhaust
 
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.rest.client.TestRemoteTable
 
beforeAllTests() - Static method in class org.apache.hadoop.hbase.master.balancer.TestRSGroupBasedLoadBalancer
 
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.mapred.TestTableOutputFormatConnectionExhaust
 
beforeClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestCellBasedImportExport2
 
beforeClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestCellBasedWALPlayer2
 
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.TestHashTable
 
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.TestSyncTable
 
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.hbase.archetypes.exemplars.client.TestHelloHBase
 
beforeClass() - Static method in class org.apache.hbase.archetypes.exemplars.shaded_client.TestHelloHBase
 
beforeExecution(Store) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker
Called before compaction is executed by CompactSplitThread.
beforeExecution() - Method in interface org.apache.hadoop.hbase.regionserver.FlushLifeCycleTracker
Called before flush is executed.
beforeMethod() - Method in class org.apache.hadoop.hbase.rest.RowResourceBase
 
beforeMethod() - Method in class org.apache.hadoop.hbase.rsgroup.IntegrationTestRSGroup
 
beforeMethod() - Method in class org.apache.hadoop.hbase.rsgroup.TestRSGroups
 
beforeReplay(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
On recovery, re-execute from start to acquire the locks.
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
 
beforeWaitOnSafePoint() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
begin() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
begin(Runnable) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Start a write transaction.
bind(ServerSocket, InetSocketAddress, int) - Static method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
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
 
BLOCK_CACHE_BLOOM_CHUNK_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_BLOOM_CHUNK_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DATA_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DATA_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DELETE_FAMILY_BLOOM_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DELETE_FAMILY_BLOOM_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_ENCODED_DATA_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_ENCODED_DATA_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EVICTION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EVICTION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EXPRESS_HIT_PERCENT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EXPRESS_HIT_PERCENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FAILED_INSERTION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FAILED_INSERTION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FILE_INFO_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FILE_INFO_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FREE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FREE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_GENERAL_BLOOM_META_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_GENERAL_BLOOM_META_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_PERCENT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_PERCENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_INTERMEDIATE_INDEX_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_INTERMEDIATE_INDEX_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_LEAF_INDEX_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_LEAF_INDEX_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_META_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_META_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_EVICTION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_EVICTION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_HIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_ROOT_INDEX_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_ROOT_INDEX_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_SIZE_MAX_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
BLOCK_CACHE_SIZE_MIN_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
BLOCK_CACHE_TRAILER_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_TRAILER_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_COUNT_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_COUNT_PRIMARY_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_STORAGE_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.rest.model.TestColumnSchemaModel
 
BLOCKCACHE_SIZE_GAUGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
BLOCKCACHE_SIZE_GAUGE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
BLOCKED_FLUSH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
BLOCKED_FLUSH_GAUGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
BLOCKED_FLUSH_GAUGE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
BLOCKED_FLUSH_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
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
 
BLOCKING_STOREFILES_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
BlockingServiceAndInterface(BlockingService, Class<?>) - Constructor for class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
 
blockOnSync(SyncFuture) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
blocksize - Variable in class org.apache.hadoop.hbase.regionserver.HStore
 
blocksize - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
Block size to use writing files.
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.rest.model.TestColumnSchemaModel
 
blockUpdates() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
blockUpdates() - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
 
BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.rest.model.TestColumnSchemaModel
 
bloomFilterType - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
 
bloomType - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
 
BOGUS_SERVER_NAME - Static variable in interface org.apache.hadoop.hbase.master.LoadBalancer
 
BOOTSTRAP_THREAD_POOL_SIZE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
boundaries - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
BoundaryMultiWriter(CellComparator, List<byte[]>, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
 
BoundaryStripeFlushRequest(CellComparator, List<byte[]>) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequest
 
Branch1CoprocessorMethods - Class in org.apache.hadoop.hbase.tool.coprocessor
 
Branch1CoprocessorMethods() - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.Branch1CoprocessorMethods
 
BROWSER_USER_AGENT_PARAM - Static variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
 
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.MobNoKillMonkeyFactory
 
build() - Method in class org.apache.hadoop.hbase.chaos.factories.MobSlowDeterministicMonkeyFactory
 
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.ServerAndDependenciesKillingMonkeyFactory
 
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.http.HttpServer.Builder
 
build() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
 
build() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
Create a store file writer.
buildClientServiceCallable(Connection, TableName, byte[], Collection<LoadIncrementalHFiles.LoadQueueItem>, boolean) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
 
buildCloseRegionRequest(ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.RegionCloseOperation
 
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.
Builder() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.Builder
 
Builder(Configuration, CacheConfig, FileSystem) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
 
Builder(Configuration, FileSystem) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
Creates Builder with cache configuration disabled
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
 
buildJMXServiceURL(int, int) - Static method in class org.apache.hadoop.hbase.JMXListener
 
buildLockRequest(LockType, String, TableName, List<RegionInfo>, String, long, long) - Static method in class org.apache.hadoop.hbase.client.locking.LockServiceClient
 
buildModelFromPut(Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildMultiRowSpec(byte[][], int) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildRegionOpenInfoRequest(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.RegionOpenOperation
 
buildReplicateWALEntryRequest(Entry[]) - Static method in class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
Create a new ReplicateWALEntryRequest from a list of WAL entries
buildReplicateWALEntryRequest(Entry[], byte[], String, Path, Path) - Static method in class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
Create a new ReplicateWALEntryRequest from a list of WAL 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
 
buildRowSpec(byte[], Map, long, long, int) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
buildSecureWALHeader(Configuration, WALHeader.Builder) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
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.TestNamespacesInstanceModel
 
buildTestModel(String, Map<String, String>) - Method in class org.apache.hadoop.hbase.rest.model.TestNamespacesInstanceModel
 
buildTestModel() - Method in class org.apache.hadoop.hbase.rest.model.TestNamespacesModel
 
buildTestModel(String...) - Method in class org.apache.hadoop.hbase.rest.model.TestNamespacesModel
 
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
 
buildWALHeader(Configuration, WALHeader.Builder) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
buildWALHeader(Configuration, WALHeader.Builder) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureAsyncProtobufLogWriter
 
buildWALHeader(Configuration, WALHeader.Builder) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogWriter
 
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_OUTPUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
BULKLOAD_DIR_NAME - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
BulkLoadCellFilter - Class in org.apache.hadoop.hbase.replication
 
BulkLoadCellFilter() - Constructor for class org.apache.hadoop.hbase.replication.BulkLoadCellFilter
 
bulkLoadHFile(byte[], String, Path) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
bulkLoadHFile(StoreFileInfo) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
bulkLoadHFile(RpcController, BulkLoadHFileRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Atomically bulk load several HFiles into an open region
bulkLoadHFiles(Collection<<any>>, boolean, HRegion.BulkLoadListener) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Attempts to atomically load a group of hfiles.
bulkLoadHFiles(Collection<<any>>, boolean, HRegion.BulkLoadListener, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Attempts to atomically load a group of hfiles.
bulkLoadPhase(Table, Connection, ExecutorService, Deque<LoadIncrementalHFiles.LoadQueueItem>, <any>, boolean, Map<LoadIncrementalHFiles.LoadQueueItem, ByteBuffer>) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
This takes the LQI's grouped by likely regions and attempts to bulk load them.
BusyRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
This class represents a split policy which makes the split decision based on how busy a region is.
BusyRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
 
bytesPerChecksum - Variable in class org.apache.hadoop.hbase.regionserver.HStore
 
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 3.0.0