Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.protobuf |
Holds classes generated from protobuf
src/main/protobuf definition files. |
org.apache.hadoop.hbase.protobuf.generated | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.replication.regionserver |
Modifier and Type | Field and Description |
---|---|
protected AdminProtos.AdminService.BlockingInterface |
RegionAdminServiceCallable.stub |
Modifier and Type | Method and Description |
---|---|
AdminProtos.AdminService.BlockingInterface |
HConnection.getAdmin(ServerName serverName)
Deprecated.
internal method, do not use thru HConnection
|
AdminProtos.AdminService.BlockingInterface |
ClusterConnection.getAdmin(ServerName serverName)
Establishes a connection to the region server at the specified address.
|
AdminProtos.AdminService.BlockingInterface |
HConnection.getAdmin(ServerName serverName,
boolean getMaster)
Deprecated.
You can pass master flag but nothing special is done.
|
Modifier and Type | Method and Description |
---|---|
static ClusterConnection |
ConnectionUtils.createShortCircuitConnection(org.apache.hadoop.conf.Configuration conf,
ExecutorService pool,
User user,
ServerName serverName,
AdminProtos.AdminService.BlockingInterface admin,
ClientProtos.ClientService.BlockingInterface client)
Creates a short-circuit connection that can bypass the RPC layer (serialization,
deserialization, networking, etc..) when talking to a local server.
|
static ClusterConnection |
ConnectionUtils.createShortCircuitHConnection(Connection conn,
ServerName serverName,
AdminProtos.AdminService.BlockingInterface admin,
ClientProtos.ClientService.BlockingInterface client)
Deprecated.
|
protected void |
RegionAdminServiceCallable.setStub(AdminProtos.AdminService.BlockingInterface stub) |
Modifier and Type | Class and Description |
---|---|
class |
MasterRpcServices
Implements the master RPC services.
|
Modifier and Type | Method and Description |
---|---|
static void |
ProtobufUtil.closeRegion(com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin,
ServerName server,
byte[] regionName,
boolean transitionInZK)
A helper to close a region given a region name
using admin protocol.
|
static boolean |
ProtobufUtil.closeRegion(com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin,
ServerName server,
byte[] regionName,
int versionOfClosingNode,
ServerName destinationServer,
boolean transitionInZK)
A helper to close a region given a region name
using admin protocol.
|
static List<HRegionInfo> |
ProtobufUtil.getOnlineRegions(AdminProtos.AdminService.BlockingInterface admin)
A helper to get the all the online regions on a region
server using admin protocol.
|
static List<HRegionInfo> |
ProtobufUtil.getOnlineRegions(com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin)
A helper to get the all the online regions on a region
server using admin protocol.
|
static HRegionInfo |
ProtobufUtil.getRegionInfo(com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin,
byte[] regionName)
A helper to retrieve region info given a region name
using admin protocol.
|
static AdminProtos.ServerInfo |
ProtobufUtil.getServerInfo(com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin)
A helper to get the info of a region server using admin protocol.
|
static List<String> |
ProtobufUtil.getStoreFiles(AdminProtos.AdminService.BlockingInterface admin,
byte[] regionName,
byte[] family)
A helper to get the list of files of a column family
on a given region using admin protocol.
|
static List<String> |
ProtobufUtil.getStoreFiles(com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin,
byte[] regionName,
byte[] family)
A helper to get the list of files of a column family
on a given region using admin protocol.
|
static void |
ProtobufUtil.mergeRegions(com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin,
HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible)
A helper to merge regions using admin protocol.
|
static void |
ProtobufUtil.openRegion(com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin,
ServerName server,
HRegionInfo region)
A helper to open a region using admin protocol.
|
static void |
ReplicationProtbufUtil.replicateWALEntry(AdminProtos.AdminService.BlockingInterface admin,
WAL.Entry[] entries)
A helper to replicate a list of WAL entries using admin protocol.
|
static void |
ProtobufUtil.split(com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin,
HRegionInfo hri,
byte[] splitPoint)
A helper to split a region using admin protocol.
|
static void |
ProtobufUtil.warmupRegion(com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin,
HRegionInfo regionInfo)
A helper to warmup a region given a region name
using admin protocol
|
Modifier and Type | Method and Description |
---|---|
static AdminProtos.AdminService.BlockingInterface |
AdminProtos.AdminService.newBlockingStub(com.google.protobuf.BlockingRpcChannel channel) |
Modifier and Type | Method and Description |
---|---|
static com.google.protobuf.BlockingService |
AdminProtos.AdminService.newReflectiveBlockingService(AdminProtos.AdminService.BlockingInterface impl) |
Modifier and Type | Class and Description |
---|---|
class |
RSRpcServices
Implements the regionserver RPC services.
|
Modifier and Type | Method and Description |
---|---|
AdminProtos.AdminService.BlockingInterface |
ReplicationSinkManager.SinkPeer.getRegionServer() |
Constructor and Description |
---|
ReplicationSinkManager.SinkPeer(ServerName serverName,
AdminProtos.AdminService.BlockingInterface regionServer) |
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.