@InterfaceAudience.Private public interface MasterServices extends Server
| Modifier and Type | Method and Description |
|---|---|
boolean |
abortProcedure(long procId,
boolean mayInterruptIfRunning)
Abort a procedure.
|
void |
addColumn(TableName tableName,
HColumnDescriptor column,
long nonceGroup,
long nonce)
Add a new column to an existing table
|
void |
checkTableModifiable(TableName tableName)
Check table is modifiable; i.e.
|
void |
createNamespace(NamespaceDescriptor descriptor)
Create a new namespace
|
long |
createTable(HTableDescriptor desc,
byte[][] splitKeys,
long nonceGroup,
long nonce)
Create a table using the given table definition.
|
void |
deleteColumn(TableName tableName,
byte[] columnName,
long nonceGroup,
long nonce)
Delete a column from an existing table
|
void |
deleteNamespace(String name)
Delete an existing namespace.
|
long |
deleteTable(TableName tableName,
long nonceGroup,
long nonce)
Delete a table
|
long |
disableTable(TableName tableName,
long nonceGroup,
long nonce)
Disable an existing table
|
void |
dispatchMergingRegions(HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible)
Merge two regions.
|
long |
enableTable(TableName tableName,
long nonceGroup,
long nonce)
Enable an existing table
|
AssignmentManager |
getAssignmentManager() |
ExecutorService |
getExecutorService() |
long |
getLastMajorCompactionTimestamp(TableName table) |
long |
getLastMajorCompactionTimestampForRegion(byte[] regionName) |
MasterCoprocessorHost |
getMasterCoprocessorHost() |
MasterFileSystem |
getMasterFileSystem() |
ProcedureExecutor<MasterProcedureEnv> |
getMasterProcedureExecutor() |
MasterQuotaManager |
getMasterQuotaManager() |
NamespaceDescriptor |
getNamespaceDescriptor(String name)
Get a namespace descriptor by name
|
ServerManager |
getServerManager() |
TableDescriptors |
getTableDescriptors() |
TableLockManager |
getTableLockManager() |
boolean |
isInitialized() |
boolean |
isMasterProcedureExecutorEnabled()
Check whether the procedure executor is enabled
|
boolean |
isServerShutdownHandlerEnabled() |
List<NamespaceDescriptor> |
listNamespaceDescriptors()
List available namespace descriptors
|
List<ProcedureInfo> |
listProcedures()
List procedures
|
List<HTableDescriptor> |
listTableDescriptorsByNamespace(String name)
Get list of table descriptors by namespace
|
List<TableName> |
listTableNamesByNamespace(String name)
Get list of table names by namespace
|
void |
modifyColumn(TableName tableName,
HColumnDescriptor descriptor,
long nonceGroup,
long nonce)
Modify the column descriptor of an existing column in an existing table
|
void |
modifyNamespace(NamespaceDescriptor descriptor)
Modify an existing namespace
|
void |
modifyTable(TableName tableName,
HTableDescriptor descriptor,
long nonceGroup,
long nonce)
Modify the descriptor of an existing table
|
boolean |
registerService(com.google.protobuf.Service instance)
Registers a new protocol buffer
Service subclass as a master coprocessor endpoint. |
void |
truncateTable(TableName tableName,
boolean preserveSplits,
long nonceGroup,
long nonce)
Truncate a table
|
getChoreService, getConfiguration, getConnection, getCoordinatedStateManager, getMetaTableLocator, getServerName, getZooKeeperAssignmentManager getAssignmentManager()
AssignmentManagerMasterFileSystem getMasterFileSystem()
MasterFileSystem utility class.ServerManager getServerManager()
ServerManager instance.ExecutorService getExecutorService()
ExecutorServiceTableLockManager getTableLockManager()
TableLockManagerMasterCoprocessorHost getMasterCoprocessorHost()
MasterCoprocessorHostMasterQuotaManager getMasterQuotaManager()
MasterQuotaManagerProcedureExecutor<MasterProcedureEnv> getMasterProcedureExecutor()
ProcedureExecutorvoid checkTableModifiable(TableName tableName) throws IOException, TableNotFoundException, TableNotDisabledException
tableName - Name of table to check.TableNotDisabledExceptionTableNotFoundExceptionIOExceptionboolean isMasterProcedureExecutorEnabled()
long createTable(HTableDescriptor desc, byte[][] splitKeys, long nonceGroup, long nonce) throws IOException
desc - The table definitionsplitKeys - Starting row keys for the initial table regions. If nullnonceGroup - nonce - a single region is created.IOExceptionlong deleteTable(TableName tableName, long nonceGroup, long nonce) throws IOException
tableName - The table namenonceGroup - nonce - IOExceptionvoid truncateTable(TableName tableName, boolean preserveSplits, long nonceGroup, long nonce) throws IOException
tableName - The table namepreserveSplits - True if the splits should be preservednonceGroup - nonce - IOExceptionvoid modifyTable(TableName tableName, HTableDescriptor descriptor, long nonceGroup, long nonce) throws IOException
tableName - The table namedescriptor - The updated table descriptornonceGroup - nonce - IOExceptionlong enableTable(TableName tableName, long nonceGroup, long nonce) throws IOException
tableName - The table namenonceGroup - nonce - IOExceptionlong disableTable(TableName tableName, long nonceGroup, long nonce) throws IOException
tableName - The table namenonceGroup - nonce - IOExceptionvoid addColumn(TableName tableName, HColumnDescriptor column, long nonceGroup, long nonce) throws IOException
tableName - The table namecolumn - The column definitionnonceGroup - nonce - IOExceptionvoid modifyColumn(TableName tableName, HColumnDescriptor descriptor, long nonceGroup, long nonce) throws IOException
tableName - The table namedescriptor - The updated column definitionnonceGroup - nonce - IOExceptionvoid deleteColumn(TableName tableName, byte[] columnName, long nonceGroup, long nonce) throws IOException
tableName - The table namecolumnName - The column namenonceGroup - nonce - IOExceptionTableDescriptors getTableDescriptors()
boolean isServerShutdownHandlerEnabled()
boolean registerService(com.google.protobuf.Service instance)
Service 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.
instance - the Service subclass instance to expose as a coprocessor endpointtrue if the registration was successful, false
otherwisevoid dispatchMergingRegions(HRegionInfo region_a, HRegionInfo region_b, boolean forcible) throws IOException
region_a - region to mergeregion_b - region to mergeforcible - true if do a compulsory merge, otherwise we will only merge
two adjacent regionsIOExceptionboolean isInitialized()
void createNamespace(NamespaceDescriptor descriptor) throws IOException
descriptor - descriptor which describes the new namespaceIOExceptionvoid modifyNamespace(NamespaceDescriptor descriptor) throws IOException
descriptor - descriptor which updates the existing namespaceIOExceptionvoid deleteNamespace(String name) throws IOException
name - namespace nameIOExceptionboolean abortProcedure(long procId,
boolean mayInterruptIfRunning)
throws IOException
procId - ID of the proceduremayInterruptIfRunning - if the proc completed at least one step, should it be aborted?IOExceptionList<ProcedureInfo> listProcedures() throws IOException
IOExceptionNamespaceDescriptor getNamespaceDescriptor(String name) throws IOException
name - name of namespace descriptorIOExceptionList<NamespaceDescriptor> listNamespaceDescriptors() throws IOException
IOExceptionList<HTableDescriptor> listTableDescriptorsByNamespace(String name) throws IOException
name - namespace nameIOExceptionList<TableName> listTableNamesByNamespace(String name) throws IOException
name - namespace nameIOExceptionlong getLastMajorCompactionTimestamp(TableName table) throws IOException
table - IOExceptionlong getLastMajorCompactionTimestampForRegion(byte[] regionName)
throws IOException
regionName - IOExceptionCopyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.