Package org.apache.hadoop.hbase.master
Class MockRegionServer
java.lang.Object
org.apache.hadoop.hbase.master.MockRegionServer
- All Implemented Interfaces:
org.apache.hadoop.hbase.Abortable,org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion,org.apache.hadoop.hbase.regionserver.MutableOnlineRegions,org.apache.hadoop.hbase.regionserver.OnlineRegions,org.apache.hadoop.hbase.regionserver.RegionServerServices,org.apache.hadoop.hbase.Server,org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface,org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface,org.apache.hadoop.hbase.Stoppable
class MockRegionServer
extends Object
implements org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface, org.apache.hadoop.hbase.regionserver.RegionServerServices
A mock RegionServer implementation. Use this when you can't bend Mockito to your liking (e.g.
return null result when 'scanning' until master timesout and then return a coherent meta row
result thereafter. Have some facility for faking gets and scans. See setGetResult(byte[], byte[],
Result) for how to fill the backing data store that the get pulls from.
-
Nested Class Summary
Nested ClassesModifier and TypeClassDescription(package private) classData structure that holds regionname and index used scanning.Nested classes/interfaces inherited from interface org.apache.hadoop.hbase.regionserver.RegionServerServices
org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext, org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext -
Field Summary
FieldsModifier and TypeFieldDescriptionprivate final org.apache.hadoop.conf.ConfigurationMap of regions to map of rows andResult.private final Map<byte[],org.apache.hadoop.hbase.client.Result[]> Map of regions to results to return when scanning.private final Map<Long,MockRegionServer.RegionNameAndIndex> Outstanding scanners and their offset intonextsprivate final org.apache.hadoop.hbase.ServerNameprivate final org.apache.hadoop.hbase.zookeeper.ZKWatcher -
Constructor Summary
ConstructorsConstructorDescriptionMockRegionServer(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ServerName sn) -
Method Summary
Modifier and TypeMethodDescriptionvoidvoidaddRegion(org.apache.hadoop.hbase.regionserver.HRegion r) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileResponsebulkLoadHFile(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadResponsecleanupBulkLoad(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearCompactionQueuesResponseclearCompactionQueues(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearCompactionQueuesRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearRegionBlockCacheResponseclearRegionBlockCache(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearRegionBlockCacheRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearSlowLogResponsesclearSlowLogsResponses(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearSlowLogResponseRequest request) voidclose(long scannerId) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CloseRegionResponsecloseRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CloseRegionRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactionSwitchResponsecompactionSwitch(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactionSwitchRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactRegionResponsecompactRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactRegionRequest request) org.apache.hadoop.hbase.client.ConnectioncreateConnection(org.apache.hadoop.conf.Configuration conf) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceResponseexecRegionServerService(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceResponseexecService(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ExecuteProceduresResponseexecuteProcedures(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ExecuteProceduresRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponseflushRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetResponseget(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetRequest request) org.apache.hadoop.hbase.security.access.AccessCheckerorg.apache.hadoop.hbase.client.AsyncClusterConnectionOptional<org.apache.hadoop.hbase.io.hfile.BlockCache>org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetCachedFilesListResponsegetCachedFilesList(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetCachedFilesListRequest request) org.apache.hadoop.hbase.ChoreServicedoubleorg.apache.hadoop.hbase.regionserver.compactions.CompactionRequesterorg.apache.hadoop.conf.Configurationorg.apache.hadoop.hbase.client.Connectionorg.apache.hadoop.hbase.CoordinatedStateManagerorg.apache.hadoop.hbase.executor.ExecutorServicegetFavoredNodesForRegion(String encodedRegionName) org.apache.hadoop.fs.FileSystemdoubleorg.apache.hadoop.hbase.regionserver.FlushRequesterorg.apache.hadoop.hbase.regionserver.throttle.ThroughputControllerorg.apache.hadoop.hbase.regionserver.HeapMemoryManagerorg.apache.hadoop.hbase.regionserver.LeaseManagerorg.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.LogEntrygetLogEntries(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.LogRequest request) org.apache.hadoop.hbase.regionserver.MetricsRegionServerOptional<org.apache.hadoop.hbase.mob.MobFileCache>org.apache.hadoop.hbase.regionserver.ServerNonceManagerorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionResponsegetOnlineRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionRequest request) org.apache.hadoop.hbase.regionserver.HRegionorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponsegetRegionInfo(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadResponsegetRegionLoad(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadRequest request) org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManagerList<org.apache.hadoop.hbase.regionserver.HRegion>List<org.apache.hadoop.hbase.regionserver.HRegion>getRegions(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.regionserver.RegionServerAccountingorg.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManagerorg.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManagerConcurrentSkipListMap<byte[],Boolean> org.apache.hadoop.hbase.regionserver.ReplicationSourceServiceorg.apache.hadoop.hbase.ipc.RpcServerInterfaceorg.apache.hadoop.hbase.regionserver.SecureBulkLoadManagerorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetServerInfoResponsegetServerInfo(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetServerInfoRequest request) org.apache.hadoop.hbase.ServerNameorg.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaSnapshotsResponsegetSpaceQuotaSnapshots(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaSnapshotsRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetStoreFileResponsegetStoreFile(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetStoreFileRequest request) org.apache.hadoop.hbase.TableDescriptorsorg.apache.hadoop.hbase.wal.WALgetWAL(org.apache.hadoop.hbase.client.RegionInfo regionInfo) List<org.apache.hadoop.hbase.wal.WAL>getWALs()org.apache.hadoop.hbase.security.access.ZKPermissionWatcherorg.apache.hadoop.hbase.zookeeper.ZKWatcherbooleanbooleanbooleanbooleanorg.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiResponsemulti(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateResponsemutate(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest request) org.apache.hadoop.hbase.client.Resultnext(long scannerId) org.apache.hadoop.hbase.client.Result[]next(long scannerId, int numberOfRows) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionResponseopenRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequest request) longopenScanner(byte[] regionName, org.apache.hadoop.hbase.client.Scan scan) voidpostOpenDeployTasks(org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext context) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadResponseprepareBulkLoad(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadRequest request) org.apache.hadoop.hbase.client.locking.EntityLockregionLock(List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos, String description, org.apache.hadoop.hbase.Abortable abort) booleanregisterService(org.apache.hbase.thirdparty.com.google.protobuf.Service service) booleanremoveRegion(org.apache.hadoop.hbase.regionserver.HRegion r, org.apache.hadoop.hbase.ServerName destination) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponsereplay(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponsereplicateToReplica(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponsereplicateWALEntry(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request) booleanreportFileArchivalForQuotas(org.apache.hadoop.hbase.TableName tableName, Collection<Map.Entry<String, Long>> archivedFiles) booleanreportRegionSizesForQuotas(org.apache.hadoop.hbase.quotas.RegionSizeStore sizeStore) booleanreportRegionStateTransition(org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext context) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.RollWALWriterResponserollWALWriter(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.RollWALWriterRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponsescan(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest request) (package private) voidsetGetResult(byte[] regionName, byte[] row, org.apache.hadoop.hbase.client.Result r) Use this method filling the backing data source used byget(RpcController, ClientProtos.GetRequest)(package private) voidsetNextResults(byte[] regionName, org.apache.hadoop.hbase.client.Result[] rs) Use this method to set what a scanner will reply as we next throughvoidorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.StopServerResponsestopServer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.StopServerRequest request) voidunassign(byte[] regionName) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateConfigurationResponseupdateConfiguration(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateConfigurationRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateFavoredNodesResponseupdateFavoredNodes(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest request) voidupdateRegionFavoredNodesMapping(String encodedRegionName, List<org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.ServerName> favoredNodes) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WarmupRegionResponsewarmupRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WarmupRegionRequest request) Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.apache.hadoop.hbase.Abortable
abortMethods inherited from interface org.apache.hadoop.hbase.Server
getAsyncConnection
-
Field Details
-
sn
-
zkw
-
conf
-
gets
Map of regions to map of rows andResult. Used as data source whenget(RpcController, ClientProtos.GetRequest)is called. Because we have a byte key, need to use TreeMap and provide a Comparator. UsesetGetResult(byte[], byte[], Result)filling this map. -
nexts
Map of regions to results to return when scanning. -
scannersAndOffsets
Outstanding scanners and their offset intonexts
-
-
Constructor Details
-
MockRegionServer
MockRegionServer(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ServerName sn) throws org.apache.hadoop.hbase.ZooKeeperConnectionException, IOException - Parameters:
sn- Name of this mock regionserver- Throws:
org.apache.hadoop.hbase.ZooKeeperConnectionExceptionIOException
-
-
Method Details
-
setGetResult
Use this method filling the backing data source used byget(RpcController, ClientProtos.GetRequest)- Parameters:
regionName- the region name to assignrow- the row keyr- the single row result
-
setNextResults
Use this method to set what a scanner will reply as we next through -
isStopped
- Specified by:
isStoppedin interfaceorg.apache.hadoop.hbase.Stoppable
-
abort
- Specified by:
abortin interfaceorg.apache.hadoop.hbase.Abortable
-
isAborted
- Specified by:
isAbortedin interfaceorg.apache.hadoop.hbase.Abortable
-
openScanner
public long openScanner(byte[] regionName, org.apache.hadoop.hbase.client.Scan scan) throws IOException - Throws:
IOException
-
next
- Throws:
IOException
-
next
public org.apache.hadoop.hbase.client.Result[] next(long scannerId, int numberOfRows) throws IOException - Throws:
IOException
-
close
- Throws:
IOException
-
stop
- Specified by:
stopin interfaceorg.apache.hadoop.hbase.Stoppable
-
addRegion
- Specified by:
addRegionin interfaceorg.apache.hadoop.hbase.regionserver.MutableOnlineRegions
-
removeRegion
public boolean removeRegion(org.apache.hadoop.hbase.regionserver.HRegion r, org.apache.hadoop.hbase.ServerName destination) - Specified by:
removeRegionin interfaceorg.apache.hadoop.hbase.regionserver.MutableOnlineRegions
-
getRegion
- Specified by:
getRegionin interfaceorg.apache.hadoop.hbase.regionserver.OnlineRegions- Specified by:
getRegionin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getConfiguration
- Specified by:
getConfigurationin interfaceorg.apache.hadoop.hbase.Server
-
getZooKeeper
- Specified by:
getZooKeeperin interfaceorg.apache.hadoop.hbase.Server
-
getCoordinatedStateManager
- Specified by:
getCoordinatedStateManagerin interfaceorg.apache.hadoop.hbase.Server
-
getConnection
- Specified by:
getConnectionin interfaceorg.apache.hadoop.hbase.Server
-
getServerName
- Specified by:
getServerNamein interfaceorg.apache.hadoop.hbase.Server
-
isStopping
- Specified by:
isStoppingin interfaceorg.apache.hadoop.hbase.Server
-
getFlushRequester
- Specified by:
getFlushRequesterin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getCompactionRequestor
public org.apache.hadoop.hbase.regionserver.compactions.CompactionRequester getCompactionRequestor()- Specified by:
getCompactionRequestorin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getRegionServerAccounting
- Specified by:
getRegionServerAccountingin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getRegionServerRpcQuotaManager
- Specified by:
getRegionServerRpcQuotaManagerin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
postOpenDeployTasks
public void postOpenDeployTasks(org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext context) throws IOException - Specified by:
postOpenDeployTasksin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices- Throws:
IOException
-
getRpcServer
- Specified by:
getRpcServerin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getRegionsInTransitionInRS
- Specified by:
getRegionsInTransitionInRSin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getFileSystem
- Specified by:
getFileSystemin interfaceorg.apache.hadoop.hbase.Server
-
get
public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetResponse get(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
getin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
mutate
public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateResponse mutate(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
mutatein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
scan
public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse scan(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
scanin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
bulkLoadHFile
public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileResponse bulkLoadHFile(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
bulkLoadHFilein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
execService
public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceResponse execService(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
execServicein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
multi
public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiResponse multi(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
multiin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getRegionInfo
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse getRegionInfo(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
getRegionInfoin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getRegionLoad
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadResponse getRegionLoad(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
getRegionLoadin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
clearCompactionQueues
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearCompactionQueuesResponse clearCompactionQueues(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearCompactionQueuesRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
clearCompactionQueuesin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getStoreFile
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetStoreFileResponse getStoreFile(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetStoreFileRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
getStoreFilein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getOnlineRegion
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionResponse getOnlineRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
getOnlineRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getCachedFilesList
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetCachedFilesListResponse getCachedFilesList(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetCachedFilesListRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
getCachedFilesListin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getRegions
- Specified by:
getRegionsin interfaceorg.apache.hadoop.hbase.regionserver.OnlineRegions- Specified by:
getRegionsin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
openRegion
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionResponse openRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
openRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
warmupRegion
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WarmupRegionResponse warmupRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WarmupRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
warmupRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
closeRegion
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CloseRegionResponse closeRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CloseRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
closeRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
flushRegion
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponse flushRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
flushRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
compactionSwitch
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactionSwitchResponse compactionSwitch(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactionSwitchRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
compactionSwitchin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
compactRegion
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactRegionResponse compactRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
compactRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
replicateWALEntry
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse replicateWALEntry(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
replicateWALEntryin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
rollWALWriter
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.RollWALWriterResponse rollWALWriter(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.RollWALWriterRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
rollWALWriterin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getServerInfo
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetServerInfoResponse getServerInfo(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetServerInfoRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
getServerInfoin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
stopServer
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.StopServerResponse stopServer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.StopServerRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
stopServerin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getRegions
public List<org.apache.hadoop.hbase.regionserver.HRegion> getRegions(org.apache.hadoop.hbase.TableName tableName) throws IOException - Specified by:
getRegionsin interfaceorg.apache.hadoop.hbase.regionserver.OnlineRegions- Specified by:
getRegionsin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices- Throws:
IOException
-
getLeaseManager
- Specified by:
getLeaseManagerin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getWALs
- Specified by:
getWALsin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices- Throws:
IOException
-
getWAL
public org.apache.hadoop.hbase.wal.WAL getWAL(org.apache.hadoop.hbase.client.RegionInfo regionInfo) throws IOException - Specified by:
getWALin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices- Throws:
IOException
-
getExecutorService
- Specified by:
getExecutorServicein interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getChoreService
- Specified by:
getChoreServicein interfaceorg.apache.hadoop.hbase.Server
-
updateRegionFavoredNodesMapping
public void updateRegionFavoredNodesMapping(String encodedRegionName, List<org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.ServerName> favoredNodes) - Specified by:
updateRegionFavoredNodesMappingin interfaceorg.apache.hadoop.hbase.regionserver.FavoredNodesForRegion
-
getFavoredNodesForRegion
- Specified by:
getFavoredNodesForRegionin interfaceorg.apache.hadoop.hbase.regionserver.FavoredNodesForRegion
-
replay
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse replay(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
replayin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
updateFavoredNodes
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse updateFavoredNodes(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
updateFavoredNodesin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getNonceManager
- Specified by:
getNonceManagerin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
reportRegionStateTransition
public boolean reportRegionStateTransition(org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext context) - Specified by:
reportRegionStateTransitionin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
registerService
- Specified by:
registerServicein interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
execRegionServerService
public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceResponse execRegionServerService(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
execRegionServerServicein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
updateConfiguration
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateConfigurationResponse updateConfiguration(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateConfigurationRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
updateConfigurationin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
clearRegionBlockCache
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearRegionBlockCacheResponse clearRegionBlockCache(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearRegionBlockCacheRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
clearRegionBlockCachein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getHeapMemoryManager
- Specified by:
getHeapMemoryManagerin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getCompactionPressure
- Specified by:
getCompactionPressurein interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getFlushThroughputController
public org.apache.hadoop.hbase.regionserver.throttle.ThroughputController getFlushThroughputController()- Specified by:
getFlushThroughputControllerin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getFlushPressure
- Specified by:
getFlushPressurein interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getMetrics
- Specified by:
getMetricsin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
regionLock
public org.apache.hadoop.hbase.client.locking.EntityLock regionLock(List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos, String description, org.apache.hadoop.hbase.Abortable abort) throws IOException - Specified by:
regionLockin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices- Throws:
IOException
-
prepareBulkLoad
public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadResponse prepareBulkLoad(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
prepareBulkLoadin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
cleanupBulkLoad
public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadResponse cleanupBulkLoad(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
cleanupBulkLoadin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getSecureBulkLoadManager
- Specified by:
getSecureBulkLoadManagerin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
unassign
- Specified by:
unassignin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices- Throws:
IOException
-
getRegionServerSpaceQuotaManager
public org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager getRegionServerSpaceQuotaManager()- Specified by:
getRegionServerSpaceQuotaManagerin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
executeProcedures
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ExecuteProceduresResponse executeProcedures(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ExecuteProceduresRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
executeProceduresin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
clearSlowLogsResponses
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearSlowLogResponses clearSlowLogsResponses(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearSlowLogResponseRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
clearSlowLogsResponsesin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getLogEntries
public org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.LogEntry getLogEntries(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.LogRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
getLogEntriesin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getSpaceQuotaSnapshots
public org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaSnapshotsResponse getSpaceQuotaSnapshots(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaSnapshotsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
getSpaceQuotaSnapshotsin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
createConnection
public org.apache.hadoop.hbase.client.Connection createConnection(org.apache.hadoop.conf.Configuration conf) throws IOException - Specified by:
createConnectionin interfaceorg.apache.hadoop.hbase.Server- Throws:
IOException
-
reportRegionSizesForQuotas
- Specified by:
reportRegionSizesForQuotasin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
reportFileArchivalForQuotas
public boolean reportFileArchivalForQuotas(org.apache.hadoop.hbase.TableName tableName, Collection<Map.Entry<String, Long>> archivedFiles) - Specified by:
reportFileArchivalForQuotasin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
isClusterUp
- Specified by:
isClusterUpin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getReplicationSourceService
- Specified by:
getReplicationSourceServicein interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getTableDescriptors
- Specified by:
getTableDescriptorsin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getBlockCache
- Specified by:
getBlockCachein interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getMobFileCache
- Specified by:
getMobFileCachein interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getAccessChecker
- Specified by:
getAccessCheckerin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getZKPermissionWatcher
- Specified by:
getZKPermissionWatcherin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
getAsyncClusterConnection
- Specified by:
getAsyncClusterConnectionin interfaceorg.apache.hadoop.hbase.Server
-
getRegionReplicationBufferManager
public org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager getRegionReplicationBufferManager()- Specified by:
getRegionReplicationBufferManagerin interfaceorg.apache.hadoop.hbase.regionserver.RegionServerServices
-
replicateToReplica
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse replicateToReplica(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
replicateToReplicain interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-