|
||||||||||
| PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
| SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD | |||||||||
java.lang.Objectorg.apache.hadoop.hbase.util.HasThread
org.apache.hadoop.hbase.master.HMaster
@InterfaceAudience.Private public class HMaster
HMaster is the "master server" for HBase. An HBase cluster has one active master. If many masters are started, all compete. Whichever wins goes on to run the cluster. All others park themselves in their constructor until master or cluster shutdown or until the active master loses its lease in zookeeper. Thereafter, all running master jostle to take over master role.
The Master can be asked shutdown the cluster. See shutdown(). In
this case it will tell all regionservers to go down and then wait on them
all reporting in that they are down. This master will then shut itself down.
You can also shutdown just this master. Call stopMaster().
Watcher| Field Summary | |
|---|---|
static String |
MASTER
|
| Constructor Summary | |
|---|---|
HMaster(org.apache.hadoop.conf.Configuration conf)
Initializes the HMaster. |
|
| Methods inherited from class org.apache.hadoop.hbase.util.HasThread |
|---|
getName, getThread, interrupt, isAlive, isInterrupted, join, join, join, setDaemon, setName, setPriority, setUncaughtExceptionHandler, start |
| Methods inherited from class java.lang.Object |
|---|
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait |
| Field Detail |
|---|
public static final String MASTER
| Constructor Detail |
|---|
public HMaster(org.apache.hadoop.conf.Configuration conf)
throws IOException,
org.apache.zookeeper.KeeperException,
InterruptedException
Remaining steps of initialization occur in run() so that they
run in their own thread rather than within the context of the constructor.
InterruptedException
IOException
org.apache.zookeeper.KeeperException| Method Detail |
|---|
public void run()
run in interface Runnablerun in class HasThreadprotected void startCatalogJanitorChore()
public TableDescriptors getTableDescriptors()
getTableDescriptors in interface MasterServicespublic InfoServer getInfoServer()
public org.apache.hadoop.conf.Configuration getConfiguration()
getConfiguration in interface Serverpublic ServerManager getServerManager()
getServerManager in interface MasterServicesServerManager instance.public ExecutorService getExecutorService()
getExecutorService in interface MasterServicesExecutorServicepublic MasterFileSystem getMasterFileSystem()
getMasterFileSystem in interface MasterServicesMasterFileSystem utility class.public ZooKeeperWatcher getZooKeeperWatcher()
public ActiveMasterManager getActiveMasterManager()
public MasterAddressTracker getMasterAddressTracker()
public org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse regionServerStartup(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest request)
throws com.google.protobuf.ServiceException
regionServerStartup in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterfacecom.google.protobuf.ServiceExceptionprotected org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder createConfigurationSubset()
public org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse getLastFlushedSequenceId(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest request)
throws com.google.protobuf.ServiceException
getLastFlushedSequenceId in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse regionServerReport(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest request)
throws com.google.protobuf.ServiceException
regionServerReport in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse reportRSFatalError(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest request)
throws com.google.protobuf.ServiceException
reportRSFatalError in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic boolean isMasterRunning()
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse isMasterRunning(com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest req)
throws com.google.protobuf.ServiceException
isMasterRunning in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse runCatalogScan(com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest req)
throws com.google.protobuf.ServiceException
runCatalogScan in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse enableCatalogJanitor(com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest req)
throws com.google.protobuf.ServiceException
enableCatalogJanitor in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse isCatalogJanitorEnabled(com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest req)
throws com.google.protobuf.ServiceException
isCatalogJanitorEnabled in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public boolean balance()
throws HBaseIOException
HBaseIOException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse balance(com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest request)
throws com.google.protobuf.ServiceException
balance in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public boolean switchBalancer(boolean b,
org.apache.hadoop.hbase.master.HMaster.BalanceSwitchMode mode)
throws IOException
b - new balancer switchmode - BalanceSwitchMode
IOException
public boolean synchronousBalanceSwitch(boolean b)
throws IOException
IOException
public boolean balanceSwitch(boolean b)
throws IOException
IOException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse setBalancerRunning(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest req)
throws com.google.protobuf.ServiceException
setBalancerRunning in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic void setCatalogJanitorEnabled(boolean b)
b - If false, the catalog janitor won't do anything.
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse dispatchMergingRegions(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest request)
throws com.google.protobuf.ServiceException
dispatchMergingRegions in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public void dispatchMergingRegions(HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible)
throws IOException
MasterServices
dispatchMergingRegions in interface MasterServicesregion_a - region to mergeregion_b - region to mergeforcible - true if do a compulsory merge, otherwise we will only merge
two adjacent regions
IOException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse moveRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest req)
throws com.google.protobuf.ServiceException
moveRegion in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public void createTable(HTableDescriptor hTableDescriptor,
byte[][] splitKeys)
throws IOException
MasterServices
createTable in interface MasterServiceshTableDescriptor - The table definitionsplitKeys - Starting row keys for the initial table regions. If null
a single region is created.
IOException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse createTable(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest req)
throws com.google.protobuf.ServiceException
createTable in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public void deleteTable(TableName tableName)
throws IOException
MasterServices
deleteTable in interface MasterServicestableName - The table name
IOException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse deleteTable(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest request)
throws com.google.protobuf.ServiceException
deleteTable in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse getSchemaAlterStatus(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest req)
throws com.google.protobuf.ServiceException
getSchemaAlterStatus in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfaceIOException
com.google.protobuf.ServiceException
public void addColumn(TableName tableName,
HColumnDescriptor columnDescriptor)
throws IOException
MasterServices
addColumn in interface MasterServicestableName - The table namecolumnDescriptor - The column definition
IOException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse addColumn(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest req)
throws com.google.protobuf.ServiceException
addColumn in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public void modifyColumn(TableName tableName,
HColumnDescriptor descriptor)
throws IOException
MasterServices
modifyColumn in interface MasterServicestableName - The table namedescriptor - The updated column definition
IOException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse modifyColumn(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest req)
throws com.google.protobuf.ServiceException
modifyColumn in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public void deleteColumn(TableName tableName,
byte[] columnName)
throws IOException
MasterServices
deleteColumn in interface MasterServicestableName - The table namecolumnName - The column name
IOException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse deleteColumn(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest req)
throws com.google.protobuf.ServiceException
deleteColumn in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public void enableTable(TableName tableName)
throws IOException
MasterServices
enableTable in interface MasterServicestableName - The table name
IOException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse enableTable(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest request)
throws com.google.protobuf.ServiceException
enableTable in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public void disableTable(TableName tableName)
throws IOException
MasterServices
disableTable in interface MasterServicestableName - The table name
IOException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse disableTable(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest request)
throws com.google.protobuf.ServiceException
disableTable in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public void modifyTable(TableName tableName,
HTableDescriptor descriptor)
throws IOException
MasterServices
modifyTable in interface MasterServicestableName - The table namedescriptor - The updated table descriptor
IOException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse modifyTable(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest req)
throws com.google.protobuf.ServiceException
modifyTable in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public void checkTableModifiable(TableName tableName)
throws IOException,
TableNotFoundException,
TableNotDisabledException
MasterServices
checkTableModifiable in interface MasterServicestableName - Name of table to check.
TableNotDisabledException
TableNotFoundException
IOException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse getClusterStatus(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest req)
throws com.google.protobuf.ServiceException
getClusterStatus in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic ClusterStatus getClusterStatus()
public String getClusterId()
public static String getLoadedCoprocessors()
public long getMasterStartTime()
public long getMasterActiveTime()
public int getRegionServerInfoPort(ServerName sn)
public String[] getCoprocessors()
public void abort(String msg,
Throwable t)
abort in interface Abortablepublic ZooKeeperWatcher getZooKeeper()
getZooKeeper in interface Serverpublic MasterCoprocessorHost getCoprocessorHost()
getCoprocessorHost in interface MasterServicesMasterCoprocessorHostpublic ServerName getServerName()
getServerName in interface Serverpublic CatalogTracker getCatalogTracker()
getCatalogTracker in interface Serverpublic AssignmentManager getAssignmentManager()
getAssignmentManager in interface MasterServicesAssignmentManagerpublic TableLockManager getTableLockManager()
getTableLockManager in interface MasterServicesTableLockManagerpublic MemoryBoundedLogMessageBuffer getRegionServerFatalLogBuffer()
public void shutdown()
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse shutdown(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest request)
throws com.google.protobuf.ServiceException
shutdown in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic void stopMaster()
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse stopMaster(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest request)
throws com.google.protobuf.ServiceException
stopMaster in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic void stop(String why)
stop in interface Stoppablepublic boolean isStopped()
isStopped in interface Stoppablepublic boolean isAborted()
isAborted in interface Abortablepublic boolean isActiveMaster()
public boolean isInitialized()
isInitialized in interface MasterServicespublic boolean isServerShutdownHandlerEnabled()
isServerShutdownHandlerEnabled in interface MasterServicespublic boolean isInitializationStartsMetaRegionAssignment()
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse assignRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest req)
throws com.google.protobuf.ServiceException
assignRegion in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic void assignRegion(HRegionInfo hri)
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse unassignRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest req)
throws com.google.protobuf.ServiceException
unassignRegion in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse getTableDescriptors(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest req)
throws com.google.protobuf.ServiceException
getTableDescriptors in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecontroller - Unused (set to null).req - GetTableDescriptorsRequest that contains:
- tableNames: requested tables, or if empty, all are requested
com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse getTableNames(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest req)
throws com.google.protobuf.ServiceException
getTableNames in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecontroller - Unused (set to null).req - GetTableNamesRequest
com.google.protobuf.ServiceExceptionpublic double getAverageLoad()
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse offlineRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest request)
throws com.google.protobuf.ServiceException
offlineRegion in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic boolean registerService(com.google.protobuf.Service instance)
MasterServicesService subclass as a master coprocessor endpoint.
Only a single instance may be registered for a given Service subclass (the
instances are keyed on Descriptors.ServiceDescriptor.getFullName().
After the first registration, subsequent calls with the same service name will fail with
a return value of false.
registerService in interface MasterServicesinstance - the Service subclass instance to expose as a coprocessor endpoint
true if the registration was successful, false
otherwise
public org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse execMasterService(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest request)
throws com.google.protobuf.ServiceException
execMasterService in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public static HMaster constructMaster(Class<? extends HMaster> masterClass,
org.apache.hadoop.conf.Configuration conf)
masterClass - conf -
public static void main(String[] args)
HMasterCommandLinepublic HFileCleaner getHFileCleaner()
public SnapshotManager getSnapshotManagerForTesting()
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse snapshot(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest request)
throws com.google.protobuf.ServiceException
snapshot in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse getCompletedSnapshots(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest request)
throws com.google.protobuf.ServiceException
getCompletedSnapshots in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse deleteSnapshot(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest request)
throws com.google.protobuf.ServiceException
deleteSnapshot in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException - wrapping SnapshotDoesNotExistException if specified snapshot did not
exist.
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse isSnapshotDone(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest request)
throws com.google.protobuf.ServiceException
isSnapshotDone in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException - wrapping UnknownSnapshotException if invalid snapshot, or
a wrapped HBaseSnapshotException with progress failure reason.
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse restoreSnapshot(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest request)
throws com.google.protobuf.ServiceException
If the specified table exists a "Restore" is executed, replacing the table schema and directory data with the content of the snapshot. The table must be disabled, or a UnsupportedOperationException will be thrown.
If the table doesn't exist a "Clone" is executed, a new table is created using the schema at the time of the snapshot, and the content of the snapshot.
The restore/clone operation does not require copying HFiles. Since HFiles are immutable the table can point to and use the same files as the original one.
restoreSnapshot in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse isRestoreSnapshotDone(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest request)
throws com.google.protobuf.ServiceException
isRestoreSnapshotDone in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException - if the operation failed.
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse execProcedure(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest request)
throws com.google.protobuf.ServiceException
execProcedure in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse isProcedureDone(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest request)
throws com.google.protobuf.ServiceException
isProcedureDone in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException - if invalid procedure, or
a failed procedure with progress failure reason.
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse modifyNamespace(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest request)
throws com.google.protobuf.ServiceException
modifyNamespace in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse createNamespace(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest request)
throws com.google.protobuf.ServiceException
createNamespace in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse deleteNamespace(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest request)
throws com.google.protobuf.ServiceException
deleteNamespace in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse getNamespaceDescriptor(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest request)
throws com.google.protobuf.ServiceException
getNamespaceDescriptor in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse listNamespaceDescriptors(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest request)
throws com.google.protobuf.ServiceException
listNamespaceDescriptors in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse listTableDescriptorsByNamespace(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest request)
throws com.google.protobuf.ServiceException
listTableDescriptorsByNamespace in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse listTableNamesByNamespace(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest request)
throws com.google.protobuf.ServiceException
listTableNamesByNamespace in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public void createNamespace(NamespaceDescriptor descriptor)
throws IOException
MasterServices
createNamespace in interface MasterServicesdescriptor - descriptor which describes the new namespace
IOException
public void modifyNamespace(NamespaceDescriptor descriptor)
throws IOException
MasterServices
modifyNamespace in interface MasterServicesdescriptor - descriptor which updates the existing namespace
IOException
public void deleteNamespace(String name)
throws IOException
MasterServices
deleteNamespace in interface MasterServicesname - namespace name
IOException
public NamespaceDescriptor getNamespaceDescriptor(String name)
throws IOException
MasterServices
getNamespaceDescriptor in interface MasterServicesname - name of namespace descriptor
IOException
public List<NamespaceDescriptor> listNamespaceDescriptors()
throws IOException
MasterServices
listNamespaceDescriptors in interface MasterServicesIOException
public List<HTableDescriptor> listTableDescriptorsByNamespace(String name)
throws IOException
MasterServices
listTableDescriptorsByNamespace in interface MasterServicesname - namespace name
IOException
public List<TableName> listTableNamesByNamespace(String name)
throws IOException
MasterServices
listTableNamesByNamespace in interface MasterServicesname - namespace name
IOException
public org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse reportRegionStateTransition(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest req)
throws com.google.protobuf.ServiceException
reportRegionStateTransition in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterfacecom.google.protobuf.ServiceException
public void truncateTable(TableName tableName,
boolean preserveSplits)
throws IOException
MasterServices
truncateTable in interface MasterServicestableName - The table namepreserveSplits - True if the splits should be preserved
IOException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse truncateTable(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest request)
throws com.google.protobuf.ServiceException
truncateTable in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse isBalancerEnabled(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest request)
throws com.google.protobuf.ServiceException
isBalancerEnabled in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic boolean isBalancerOn()
LoadBalancerTracker. If the balancer is not initialized,
false is returned.
public String getLoadBalancerClassName()
LoadBalancer class name. If none is set, a default is returned.
LoadBalancer in use.
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SecurityCapabilitiesResponse getSecurityCapabilities(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SecurityCapabilitiesRequest request)
throws com.google.protobuf.ServiceException
getSecurityCapabilities in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterfacecom.google.protobuf.ServiceException
|
||||||||||
| PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
| SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD | |||||||||