Modifier and Type | Field and Description |
---|---|
static TableName |
TableName.META_TABLE_NAME
The hbase:meta table's name.
|
static TableName |
TableName.NAMESPACE_TABLE_NAME
The Namespace table's name.
|
static TableName |
TableName.OLD_META_TABLE_NAME
TableName for old .META.
|
static TableName |
TableName.OLD_ROOT_TABLE_NAME
TableName for old -ROOT- table.
|
Modifier and Type | Method and Description |
---|---|
TableName |
HRegionInfo.getTable()
Get current table name of the region
|
static TableName |
HRegionInfo.getTable(byte[] regionName)
Gets the table name from the specified region name.
|
TableName |
HTableDescriptor.getTableName()
Get the name of the table
|
static TableName |
TableName.valueOf(byte[] fullName) |
static TableName |
TableName.valueOf(byte[] namespace,
byte[] qualifier) |
static TableName |
TableName.valueOf(ByteBuffer namespace,
ByteBuffer qualifier) |
static TableName |
TableName.valueOf(String name) |
static TableName |
TableName.valueOf(String namespaceAsString,
String qualifierAsString) |
Modifier and Type | Method and Description |
---|---|
int |
TableName.compareTo(TableName tableName)
For performance reasons, the ordering is not lexicographic.
|
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
byte[] id,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
long regionid,
boolean newFormat)
Make a region name of passed parameters.
|
static byte[] |
HRegionInfo.createRegionName(TableName tableName,
byte[] startKey,
String id,
boolean newFormat)
Make a region name of passed parameters.
|
HTableDescriptor |
TableDescriptors.get(TableName tableName) |
HTableInterface |
CoprocessorEnvironment.getTable(TableName tableName) |
HTableInterface |
CoprocessorEnvironment.getTable(TableName tableName,
ExecutorService service) |
HTableDescriptor |
TableDescriptors.remove(TableName tablename) |
void |
HTableDescriptor.setName(TableName name)
Deprecated.
|
Constructor and Description |
---|
HRegionInfo(TableName tableName) |
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey)
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split)
Construct HRegionInfo with explicit parameters
|
HRegionInfo(TableName tableName,
byte[] startKey,
byte[] endKey,
boolean split,
long regionid)
Construct HRegionInfo with explicit parameters
|
HTableDescriptor(TableName name)
Construct a table descriptor specifying a TableName object
|
HTableDescriptor(TableName name,
HColumnDescriptor[] families)
INTERNAL Private constructor used internally creating table descriptors for
catalog tables,
hbase:meta and -ROOT- . |
HTableDescriptor(TableName name,
HColumnDescriptor[] families,
Map<ImmutableBytesWritable,ImmutableBytesWritable> values)
INTERNAL Private constructor used internally creating table descriptors for
catalog tables,
hbase:meta and -ROOT- . |
TableExistsException(TableName t) |
TableNotDisabledException(TableName tableName) |
TableNotEnabledException(TableName tableName) |
TableNotFoundException(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
static Scan |
MetaReader.getScanForTableName(TableName tableName)
This method creates a Scan object that will only scan catalog rows that
belong to the specified table.
|
static List<HRegionInfo> |
MetaReader.getTableRegions(CatalogTracker catalogTracker,
TableName tableName)
Gets all of the regions of the specified table.
|
static List<HRegionInfo> |
MetaReader.getTableRegions(CatalogTracker catalogTracker,
TableName tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table.
|
static List<Pair<HRegionInfo,ServerName>> |
MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
TableName tableName) |
static List<Pair<HRegionInfo,ServerName>> |
MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
TableName tableName,
boolean excludeOfflinedSplitParents) |
static boolean |
MetaReader.tableExists(CatalogTracker catalogTracker,
TableName tableName)
Checks if the specified table exists.
|
Modifier and Type | Method and Description |
---|---|
static Map<HRegionInfo,ServerName> |
MetaReader.fullScan(CatalogTracker catalogTracker,
Set<TableName> disabledTables)
Performs a full scan of
hbase:meta , skipping regions from any
tables in the specified set of disabled tables. |
static Map<HRegionInfo,ServerName> |
MetaReader.fullScan(CatalogTracker catalogTracker,
Set<TableName> disabledTables,
boolean excludeOfflinedSplitParents)
Performs a full scan of
hbase:meta , skipping regions from any
tables in the specified set of disabled tables. |
Modifier and Type | Field and Description |
---|---|
protected TableName |
RegionServerCallable.tableName |
Modifier and Type | Method and Description |
---|---|
TableName |
HTable.getName() |
TableName |
HTableInterface.getName()
Gets the fully qualified table name instance of this table.
|
protected TableName |
ClientScanner.getTable() |
TableName |
RegionServerCallable.getTableName() |
TableName[] |
HBaseAdmin.listTableNames()
List all of the names of userspace tables.
|
TableName[] |
HConnection.listTableNames() |
TableName[] |
HConnectionManager.HConnectionImplementation.listTableNames() |
TableName[] |
HBaseAdmin.listTableNamesByNamespace(String name)
Get list of table names by namespace
|
Modifier and Type | Method and Description |
---|---|
void |
HBaseAdmin.addColumn(TableName tableName,
HColumnDescriptor column)
Add a column to an existing table.
|
static NavigableMap<HRegionInfo,ServerName> |
MetaScanner.allTableRegions(org.apache.hadoop.conf.Configuration conf,
HConnection connection,
TableName tableName,
boolean offlined)
Lists all of the table regions currently in META.
|
void |
HConnection.clearRegionCache(TableName tableName)
Allows flushing the region cache of all locations that pertain to
tableName |
void |
HConnectionManager.HConnectionImplementation.clearRegionCache(TableName tableName) |
void |
HBaseAdmin.cloneSnapshot(byte[] snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
void |
HBaseAdmin.cloneSnapshot(String snapshotName,
TableName tableName)
Create a new table by cloning the snapshot content.
|
protected <R> org.apache.hadoop.hbase.client.AsyncProcess |
HConnectionManager.HConnectionImplementation.createAsyncProcess(TableName tableName,
ExecutorService pool,
org.apache.hadoop.hbase.client.AsyncProcess.AsyncProcessCallback<R> callback,
org.apache.hadoop.conf.Configuration conf) |
void |
HBaseAdmin.deleteColumn(TableName tableName,
byte[] columnName)
Delete a column from a table.
|
void |
HBaseAdmin.deleteTable(TableName tableName)
Deletes a table.
|
void |
HBaseAdmin.disableTable(TableName tableName)
Disable table and wait on completion.
|
void |
HBaseAdmin.disableTableAsync(TableName tableName)
Starts the disable of a table.
|
void |
HBaseAdmin.enableTable(TableName tableName)
Enable a table.
|
void |
HBaseAdmin.enableTableAsync(TableName tableName)
Brings a table on-line (enables it).
|
Pair<Integer,Integer> |
HBaseAdmin.getAlterStatus(TableName tableName)
Get the status of alter command - indicates how many regions have received
the updated schema Asynchronous operation.
|
HTableDescriptor |
HConnection.getHTableDescriptor(TableName tableName) |
HTableDescriptor |
HConnectionManager.HConnectionImplementation.getHTableDescriptor(TableName tableName)
Connects to the master to get the table descriptor.
|
static boolean |
HTable.getRegionCachePrefetch(org.apache.hadoop.conf.Configuration conf,
TableName tableName) |
boolean |
HConnection.getRegionCachePrefetch(TableName tableName)
Check whether region cache prefetch is enabled or not.
|
boolean |
HConnectionManager.HConnectionImplementation.getRegionCachePrefetch(TableName tableName) |
static boolean |
HTable.getRegionCachePrefetch(TableName tableName) |
HRegionLocation |
HConnection.getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
Find region location hosting passed row
|
HRegionLocation |
HConnectionManager.HConnectionImplementation.getRegionLocation(TableName tableName,
byte[] row,
boolean reload) |
HTableInterface |
HConnection.getTable(TableName tableName)
Retrieve an HTableInterface implementation for access to a table.
|
HTableInterface |
HConnectionManager.HConnectionImplementation.getTable(TableName tableName) |
HTableInterface |
HConnection.getTable(TableName tableName,
ExecutorService pool)
Retrieve an HTableInterface implementation for access to a table.
|
HTableInterface |
HConnectionManager.HConnectionImplementation.getTable(TableName tableName,
ExecutorService pool) |
HTableDescriptor |
HBaseAdmin.getTableDescriptor(TableName tableName)
Method for getting the tableDescriptor
|
List<HRegionInfo> |
HBaseAdmin.getTableRegions(TableName tableName)
get the regions of a given table.
|
boolean |
HBaseAdmin.isTableAvailable(TableName tableName) |
boolean |
HConnection.isTableAvailable(TableName tableName) |
boolean |
HConnectionManager.HConnectionImplementation.isTableAvailable(TableName tableName) |
boolean |
HBaseAdmin.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Use this api to check if the table has been created with the specified number of
splitkeys which was used while creating the given table.
|
boolean |
HConnection.isTableAvailable(TableName tableName,
byte[][] splitKeys)
Use this api to check if the table has been created with the specified number of
splitkeys which was used while creating the given table.
|
boolean |
HConnectionManager.HConnectionImplementation.isTableAvailable(TableName tableName,
byte[][] splitKeys) |
boolean |
HBaseAdmin.isTableDisabled(TableName tableName) |
boolean |
HConnection.isTableDisabled(TableName tableName) |
boolean |
HConnectionManager.HConnectionImplementation.isTableDisabled(TableName tableName) |
static boolean |
HTable.isTableEnabled(org.apache.hadoop.conf.Configuration conf,
TableName tableName)
|
boolean |
HBaseAdmin.isTableEnabled(TableName tableName) |
boolean |
HConnection.isTableEnabled(TableName tableName)
A table that isTableEnabled == false and isTableDisabled == false
is possible.
|
boolean |
HConnectionManager.HConnectionImplementation.isTableEnabled(TableName tableName) |
static boolean |
HTable.isTableEnabled(TableName tableName)
Deprecated.
|
HRegionLocation |
HConnection.locateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row
lives in.
|
HRegionLocation |
HConnectionManager.HConnectionImplementation.locateRegion(TableName tableName,
byte[] row) |
List<HRegionLocation> |
HConnection.locateRegions(TableName tableName)
Gets the locations of all regions in the specified table, tableName.
|
List<HRegionLocation> |
HConnectionManager.HConnectionImplementation.locateRegions(TableName tableName) |
List<HRegionLocation> |
HConnection.locateRegions(TableName tableName,
boolean useCache,
boolean offlined)
Gets the locations of all regions in the specified table, tableName.
|
List<HRegionLocation> |
HConnectionManager.HConnectionImplementation.locateRegions(TableName tableName,
boolean useCache,
boolean offlined) |
static void |
MetaScanner.metaScan(org.apache.hadoop.conf.Configuration configuration,
HConnection connection,
MetaScanner.MetaScannerVisitor visitor,
TableName userTableName)
Scans the meta table and calls a visitor on each RowResult.
|
static void |
MetaScanner.metaScan(org.apache.hadoop.conf.Configuration configuration,
HConnection connection,
MetaScanner.MetaScannerVisitor visitor,
TableName tableName,
byte[] row,
int rowLimit,
TableName metaTableName)
Scans the meta table and calls a visitor on each RowResult.
|
static void |
MetaScanner.metaScan(org.apache.hadoop.conf.Configuration configuration,
MetaScanner.MetaScannerVisitor visitor,
TableName userTableName,
byte[] row,
int rowLimit)
Scans the meta table and calls a visitor on each RowResult.
|
void |
HBaseAdmin.modifyColumn(TableName tableName,
HColumnDescriptor descriptor)
Modify an existing column family on a table.
|
void |
HBaseAdmin.modifyTable(TableName tableName,
HTableDescriptor htd)
Modify an existing table, more IRB friendly version.
|
void |
HConnection.processBatch(List<? extends Row> actions,
TableName tableName,
ExecutorService pool,
Object[] results)
Deprecated.
|
void |
HConnectionManager.HConnectionImplementation.processBatch(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results)
Deprecated.
|
<R> void |
HConnection.processBatchCallback(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
|
<R> void |
HConnectionManager.HConnectionImplementation.processBatchCallback(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
|
List<Put> |
HTableMultiplexer.put(TableName tableName,
List<Put> puts)
The puts request will be buffered by their corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put)
The put request will be buffered by its corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put,
int retry)
The put request will be buffered by its corresponding buffer queue.
|
HRegionLocation |
HConnection.relocateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row
lives in, ignoring any value that might be in the cache.
|
HRegionLocation |
HConnectionManager.HConnectionImplementation.relocateRegion(TableName tableName,
byte[] row) |
static void |
HTable.setRegionCachePrefetch(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
boolean enable) |
void |
HConnection.setRegionCachePrefetch(TableName tableName,
boolean enable)
Enable or disable region cache prefetch for the table.
|
void |
HConnectionManager.HConnectionImplementation.setRegionCachePrefetch(TableName tableName,
boolean enable) |
static void |
HTable.setRegionCachePrefetch(TableName tableName,
boolean enable) |
void |
HBaseAdmin.snapshot(byte[] snapshotName,
TableName tableName)
public void snapshot(final String snapshotName,
Create a timestamp consistent snapshot for the given table.
|
void |
HBaseAdmin.snapshot(String snapshotName,
TableName tableName)
Take a snapshot for the given table.
|
void |
HBaseAdmin.snapshot(String snapshotName,
TableName tableName,
HBaseProtos.SnapshotDescription.Type type)
Create typed snapshot of the table.
|
boolean |
HBaseAdmin.tableExists(TableName tableName) |
void |
HConnection.updateCachedLocations(TableName tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
Update the location cache.
|
void |
HConnectionManager.HConnectionImplementation.updateCachedLocations(TableName tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
Update the location with the new value (if the exception is a RegionMovedException)
or delete it from the cache.
|
Modifier and Type | Method and Description |
---|---|
HTableDescriptor[] |
HConnection.getHTableDescriptorsByTableName(List<TableName> tableNames) |
HTableDescriptor[] |
HConnectionManager.HConnectionImplementation.getHTableDescriptorsByTableName(List<TableName> tableNames) |
HTableDescriptor[] |
HBaseAdmin.getTableDescriptorsByTableName(List<TableName> tableNames)
Get tableDescriptors
|
Constructor and Description |
---|
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName)
Deprecated.
|
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection)
Create a new ClientScanner for the specified table
Note that the passed
Scan 's start row maybe changed changed. |
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection,
RpcRetryingCallerFactory rpcFactory)
|
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory)
Create a new ClientScanner for the specified table Note that the passed
Scan 's start
row maybe changed changed. |
ClientSmallReversedScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection)
Create a new ReversibleClientScanner for the specified table Note that the
passed
Scan 's start row maybe changed. |
ClientSmallScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName)
Create a new ClientSmallScanner for the specified table.
|
ClientSmallScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection)
Create a new ClientSmallScanner for the specified table.
|
ClientSmallScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory)
Create a new ShortClientScanner for the specified table Note that the
passed
Scan 's start row maybe changed changed. |
HTable(org.apache.hadoop.conf.Configuration conf,
TableName tableName)
Creates an object to access a HBase table.
|
HTable(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
ExecutorService pool)
Creates an object to access a HBase table.
|
HTable(TableName tableName,
HConnection connection)
Creates an object to access a HBase table.
|
HTable(TableName tableName,
HConnection connection,
ExecutorService pool)
Creates an object to access a HBase table.
|
MetaScanner.TableMetaScannerVisitor(TableName tableName) |
RegionServerCallable(HConnection connection,
TableName tableName,
byte[] row) |
ReversedClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection)
Create a new ReversibleClientScanner for the specified table Note that the
passed
Scan 's start row maybe changed. |
ReversedScannerCallable(HConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
byte[] locateStartRow)
Deprecated.
|
ReversedScannerCallable(HConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
byte[] locateStartRow,
PayloadCarryingRpcController rpcFactory) |
ScannerCallable(HConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
PayloadCarryingRpcController controller) |
Modifier and Type | Method and Description |
---|---|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.avg(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handle for calling the average method for
a given cf-cq combination.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.max(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the maximum value of a column for a given column family for the
given range.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.median(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handler for calling the median method for a
given cf-cq combination.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.min(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the minimum value of a column for a given column family for the
given range.
|
String |
SecureBulkLoadClient.prepareBulkLoad(TableName tableName) |
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.rowCount(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the row count, by summing up the individual results obtained from
regions.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.std(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handle for calling the std method for a
given cf-cq combination.
|
<R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
AggregationClient.sum(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It sums up the value returned from various regions.
|
Modifier and Type | Method and Description |
---|---|
void |
BaseMasterAndRegionObserver.preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableName> tableNamesList,
List<HTableDescriptor> descriptors) |
void |
BaseMasterObserver.preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableName> tableNamesList,
List<HTableDescriptor> descriptors) |
void |
MasterObserver.preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableName> tableNamesList,
List<HTableDescriptor> descriptors)
Called before a getTableDescriptors request has been processed.
|
Modifier and Type | Method and Description |
---|---|
static TableName |
HFileLink.getReferencedTableName(String fileName)
Get the Table name of the referenced link
|
Modifier and Type | Method and Description |
---|---|
static boolean |
HFileLink.create(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path dstFamilyPath,
TableName linkedTable,
String linkedRegion,
String hfileName)
Create a new HFileLink
|
static HFileLink |
HFileLink.create(org.apache.hadoop.conf.Configuration conf,
TableName table,
String region,
String family,
String hfile)
Create an HFileLink instance from table/region/family/hfile location
|
static String |
HFileLink.createHFileLinkName(TableName tableName,
String regionName,
String hfileName)
Create a new HFileLink name
|
static org.apache.hadoop.fs.Path |
HFileLink.createPath(TableName table,
String region,
String family,
String hfile)
Create an HFileLink relative path for the table/region/family/hfile location
|
Modifier and Type | Method and Description |
---|---|
void |
DelegatingPayloadCarryingRpcController.setPriority(TableName tn) |
void |
PayloadCarryingRpcController.setPriority(TableName tn) |
Constructor and Description |
---|
RegionCoprocessorRpcChannel(HConnection conn,
TableName table,
byte[] row,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory rpcControllerFactory) |
Modifier and Type | Method and Description |
---|---|
TableName |
TableSplit.getTable()
Deprecated.
|
Constructor and Description |
---|
TableSplit(TableName tableName,
byte[] startRow,
byte[] endRow,
String location)
Deprecated.
Constructor
|
Modifier and Type | Method and Description |
---|---|
TableName |
TableSplit.getTable()
Returns the table name.
|
Modifier and Type | Method and Description |
---|---|
protected List<org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles.LoadQueueItem> |
LoadIncrementalHFiles.tryAtomicRegionLoad(HConnection conn,
TableName tableName,
byte[] first,
Collection<org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles.LoadQueueItem> lqis)
Attempts to do an atomic load of many hfiles into a region.
|
Constructor and Description |
---|
TableSplit(TableName tableName,
byte[] startRow,
byte[] endRow,
String location)
Creates a new instance without a scanner.
|
TableSplit(TableName tableName,
byte[] startRow,
byte[] endRow,
String location,
long length)
Creates a new instance without a scanner.
|
TableSplit(TableName tableName,
Scan scan,
byte[] startRow,
byte[] endRow,
String location)
Creates a new instance while assigning all variables.
|
TableSplit(TableName tableName,
Scan scan,
byte[] startRow,
byte[] endRow,
String location,
long length)
Creates a new instance while assigning all variables.
|
Modifier and Type | Method and Description |
---|---|
protected Map<TableName,Map<ServerName,List<HRegionInfo>>> |
RegionStates.getAssignmentsByTable()
This is an EXPENSIVE clone.
|
Map<TableName,Integer> |
RegionPlacementMaintainer.getRegionsMovement(FavoredNodesPlan newPlan)
Return how many regions will move per table since their primary RS will
change
|
Set<TableName> |
SnapshotOfRegionAssignmentFromMeta.getTableSet()
Get the table set
|
Map<TableName,List<HRegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getTableToRegionMap()
Get regions for tables
|
List<TableName> |
HMaster.listTableNamesByNamespace(String name) |
List<TableName> |
MasterServices.listTableNamesByNamespace(String name)
Get list of table names by namespace
|
Modifier and Type | Method and Description |
---|---|
void |
HMaster.addColumn(TableName tableName,
HColumnDescriptor columnDescriptor) |
void |
MasterServices.addColumn(TableName tableName,
HColumnDescriptor column)
Add a new column to an existing table
|
HTableDescriptor |
MasterFileSystem.addColumn(TableName tableName,
HColumnDescriptor hcd)
Add column to a table
|
void |
HMaster.checkTableModifiable(TableName tableName) |
void |
MasterServices.checkTableModifiable(TableName tableName)
Check table is modifiable; i.e.
|
void |
HMaster.deleteColumn(TableName tableName,
byte[] columnName) |
void |
MasterServices.deleteColumn(TableName tableName,
byte[] columnName)
Delete a column from an existing table
|
HTableDescriptor |
MasterFileSystem.deleteColumn(TableName tableName,
byte[] familyName)
Delete column of a table
|
void |
HMaster.deleteTable(TableName tableName) |
void |
MasterServices.deleteTable(TableName tableName)
Delete a table
|
void |
MasterFileSystem.deleteTable(TableName tableName) |
void |
HMaster.disableTable(TableName tableName) |
void |
MasterServices.disableTable(TableName tableName)
Disable an existing table
|
void |
HMaster.enableTable(TableName tableName) |
void |
MasterServices.enableTable(TableName tableName)
Enable an existing table
|
void |
AssignmentVerificationReport.fillUp(TableName tableName,
SnapshotOfRegionAssignmentFromMeta snapshot,
Map<String,Map<String,Float>> regionLocalityMap) |
void |
AssignmentVerificationReport.fillUpDispersion(TableName tableName,
SnapshotOfRegionAssignmentFromMeta snapshot,
FavoredNodesPlan newPlan)
Use this to project the dispersion scores
|
List<HRegionInfo> |
RegionStates.getRegionsOfTable(TableName tableName)
Gets the online regions of the specified table.
|
Pair<Integer,Integer> |
AssignmentManager.getReopenStatus(TableName tableName)
Used by the client to identify if all regions have the schema updates
|
void |
HMaster.modifyColumn(TableName tableName,
HColumnDescriptor descriptor) |
void |
MasterServices.modifyColumn(TableName tableName,
HColumnDescriptor descriptor)
Modify the column descriptor of an existing column in an existing table
|
HTableDescriptor |
MasterFileSystem.modifyColumn(TableName tableName,
HColumnDescriptor hcd)
Modify Column of a table
|
void |
HMaster.modifyTable(TableName tableName,
HTableDescriptor descriptor) |
void |
MasterServices.modifyTable(TableName tableName,
HTableDescriptor descriptor)
Modify the descriptor of an existing table
|
org.apache.hadoop.fs.Path |
MasterFileSystem.moveTableToTemp(TableName tableName)
Move the specified table to the hbase temp directory
|
void |
MasterCoprocessorHost.postAddColumn(TableName tableName,
HColumnDescriptor column) |
void |
MasterCoprocessorHost.postAddColumnHandler(TableName tableName,
HColumnDescriptor column) |
void |
MasterCoprocessorHost.postDeleteColumn(TableName tableName,
byte[] c) |
void |
MasterCoprocessorHost.postDeleteColumnHandler(TableName tableName,
byte[] c) |
void |
MasterCoprocessorHost.postDeleteTable(TableName tableName) |
void |
MasterCoprocessorHost.postDeleteTableHandler(TableName tableName) |
void |
MasterCoprocessorHost.postDisableTable(TableName tableName) |
void |
MasterCoprocessorHost.postDisableTableHandler(TableName tableName) |
void |
MasterCoprocessorHost.postEnableTable(TableName tableName) |
void |
MasterCoprocessorHost.postEnableTableHandler(TableName tableName) |
void |
MasterCoprocessorHost.postModifyColumn(TableName tableName,
HColumnDescriptor descriptor) |
void |
MasterCoprocessorHost.postModifyColumnHandler(TableName tableName,
HColumnDescriptor descriptor) |
void |
MasterCoprocessorHost.postModifyTable(TableName tableName,
HTableDescriptor htd) |
void |
MasterCoprocessorHost.postModifyTableHandler(TableName tableName,
HTableDescriptor htd) |
boolean |
MasterCoprocessorHost.preAddColumn(TableName tableName,
HColumnDescriptor column) |
boolean |
MasterCoprocessorHost.preAddColumnHandler(TableName tableName,
HColumnDescriptor column) |
boolean |
MasterCoprocessorHost.preDeleteColumn(TableName tableName,
byte[] c) |
boolean |
MasterCoprocessorHost.preDeleteColumnHandler(TableName tableName,
byte[] c) |
void |
MasterCoprocessorHost.preDeleteTable(TableName tableName) |
void |
MasterCoprocessorHost.preDeleteTableHandler(TableName tableName) |
void |
MasterCoprocessorHost.preDisableTable(TableName tableName) |
void |
MasterCoprocessorHost.preDisableTableHandler(TableName tableName) |
void |
MasterCoprocessorHost.preEnableTable(TableName tableName) |
void |
MasterCoprocessorHost.preEnableTableHandler(TableName tableName) |
boolean |
MasterCoprocessorHost.preModifyColumn(TableName tableName,
HColumnDescriptor descriptor) |
boolean |
MasterCoprocessorHost.preModifyColumnHandler(TableName tableName,
HColumnDescriptor descriptor) |
void |
MasterCoprocessorHost.preModifyTable(TableName tableName,
HTableDescriptor htd) |
void |
MasterCoprocessorHost.preModifyTableHandler(TableName tableName,
HTableDescriptor htd) |
void |
RegionPlacementMaintainer.printDispersionScores(TableName table,
SnapshotOfRegionAssignmentFromMeta snapshot,
int numRegions,
FavoredNodesPlan newPlan,
boolean simplePrint) |
abstract TableLockManager.TableLock |
TableLockManager.readLock(TableName tableName,
String purpose)
Returns a TableLock for locking the table for shared access among read-lock holders
|
TableLockManager.TableLock |
TableLockManager.NullTableLockManager.readLock(TableName tableName,
String purpose) |
protected void |
AssignmentManager.setEnabledTable(TableName tableName) |
abstract void |
TableLockManager.tableDeleted(TableName tableName)
Called after a table has been deleted, and after the table lock is released.
|
void |
TableLockManager.NullTableLockManager.tableDeleted(TableName tableName) |
void |
RegionStates.tableDeleted(TableName tableName)
A table is deleted.
|
abstract TableLockManager.TableLock |
TableLockManager.writeLock(TableName tableName,
String purpose)
Returns a TableLock for locking the table for exclusive access
|
TableLockManager.TableLock |
TableLockManager.NullTableLockManager.writeLock(TableName tableName,
String purpose) |
Modifier and Type | Method and Description |
---|---|
void |
RegionPlacementMaintainer.checkDifferencesWithOldPlan(Map<TableName,Integer> movesPerTable,
Map<String,Map<String,Float>> regionLocalityMap,
FavoredNodesPlan newPlan)
Compares two plans and check whether the locality dropped or increased
(prints the information as a string) also prints the baseline locality
|
boolean |
MasterCoprocessorHost.preGetTableDescriptors(List<TableName> tableNamesList,
List<HTableDescriptor> descriptors) |
Constructor and Description |
---|
SnapshotOfRegionAssignmentFromMeta(CatalogTracker tracker,
Set<TableName> disabledTables,
boolean excludeOfflinedSplitParents) |
Modifier and Type | Field and Description |
---|---|
protected TableName |
TableEventHandler.tableName |
Modifier and Type | Method and Description |
---|---|
protected List<HRegionInfo> |
CreateTableHandler.handleCreateHdfsRegions(org.apache.hadoop.fs.Path tableRootDir,
TableName tableName)
Create the on-disk structure for the table, and returns the regions info.
|
Constructor and Description |
---|
DeleteTableHandler(TableName tableName,
Server server,
MasterServices masterServices) |
DisableTableHandler(Server server,
TableName tableName,
CatalogTracker catalogTracker,
AssignmentManager assignmentManager,
TableLockManager tableLockManager,
boolean skipTableStateCheck) |
EnableTableHandler(Server server,
TableName tableName,
CatalogTracker catalogTracker,
AssignmentManager assignmentManager,
TableLockManager tableLockManager,
boolean skipTableStateCheck) |
ModifyTableHandler(TableName tableName,
HTableDescriptor htd,
Server server,
MasterServices masterServices) |
TableAddFamilyHandler(TableName tableName,
HColumnDescriptor familyDesc,
Server server,
MasterServices masterServices) |
TableDeleteFamilyHandler(TableName tableName,
byte[] familyName,
Server server,
MasterServices masterServices) |
TableEventHandler(EventType eventType,
TableName tableName,
Server server,
MasterServices masterServices) |
TableModifyFamilyHandler(TableName tableName,
HColumnDescriptor familyDesc,
Server server,
MasterServices masterServices) |
Modifier and Type | Field and Description |
---|---|
protected TableName |
TakeSnapshotHandler.snapshotTable |
Modifier and Type | Method and Description |
---|---|
protected List<HRegionInfo> |
CloneSnapshotHandler.handleCreateHdfsRegions(org.apache.hadoop.fs.Path tableRootDir,
TableName tableName)
Create the on-disk regions, using the tableRootDir provided by the CreateTableHandler.
|
void |
SnapshotManager.setSnapshotHandlerForTesting(TableName tableName,
SnapshotSentinel handler)
Set the handler for the current snapshot
|
Modifier and Type | Method and Description |
---|---|
static TableName[] |
ProtobufUtil.getTableNameArray(List<HBaseProtos.TableName> tableNamesList) |
static TableName |
ProtobufUtil.toTableName(HBaseProtos.TableName tableNamePB) |
Modifier and Type | Method and Description |
---|---|
static MasterProtos.AddColumnRequest |
RequestConverter.buildAddColumnRequest(TableName tableName,
HColumnDescriptor column)
Create a protocol buffer AddColumnRequest
|
static MasterProtos.DeleteColumnRequest |
RequestConverter.buildDeleteColumnRequest(TableName tableName,
byte[] columnName)
Create a protocol buffer DeleteColumnRequest
|
static MasterProtos.DeleteTableRequest |
RequestConverter.buildDeleteTableRequest(TableName tableName)
Creates a protocol buffer DeleteTableRequest
|
static MasterProtos.DisableTableRequest |
RequestConverter.buildDisableTableRequest(TableName tableName)
Creates a protocol buffer DisableTableRequest
|
static MasterProtos.EnableTableRequest |
RequestConverter.buildEnableTableRequest(TableName tableName)
Creates a protocol buffer EnableTableRequest
|
static MasterProtos.GetSchemaAlterStatusRequest |
RequestConverter.buildGetSchemaAlterStatusRequest(TableName tableName)
Creates a protocol buffer GetSchemaAlterStatusRequest
|
static MasterProtos.GetTableDescriptorsRequest |
RequestConverter.buildGetTableDescriptorsRequest(TableName tableName)
Creates a protocol buffer GetTableDescriptorsRequest for a single table
|
static AccessControlProtos.GrantRequest |
RequestConverter.buildGrantRequest(String username,
TableName tableName,
byte[] family,
byte[] qualifier,
AccessControlProtos.Permission.Action... actions)
Create a request to grant user permissions.
|
static MasterProtos.ModifyColumnRequest |
RequestConverter.buildModifyColumnRequest(TableName tableName,
HColumnDescriptor column)
Create a protocol buffer ModifyColumnRequest
|
static MasterProtos.ModifyTableRequest |
RequestConverter.buildModifyTableRequest(TableName tableName,
HTableDescriptor hTableDesc)
Creates a protocol buffer ModifyTableRequest
|
static AccessControlProtos.RevokeRequest |
RequestConverter.buildRevokeRequest(String username,
TableName tableName,
byte[] family,
byte[] qualifier,
AccessControlProtos.Permission.Action... actions)
Create a request to revoke user permissions.
|
static List<UserPermission> |
ProtobufUtil.getUserPermissions(AccessControlProtos.AccessControlService.BlockingInterface protocol,
TableName t)
A utility used to get user table permissions.
|
static void |
ProtobufUtil.grant(AccessControlProtos.AccessControlService.BlockingInterface protocol,
String userShortName,
TableName tableName,
byte[] f,
byte[] q,
Permission.Action... actions)
A utility used to grant a user table permissions.
|
static void |
ProtobufUtil.revoke(AccessControlProtos.AccessControlService.BlockingInterface protocol,
String userShortName,
TableName tableName,
byte[] f,
byte[] q,
Permission.Action... actions)
A utility used to revoke a user's table permissions.
|
static HBaseProtos.TableName |
ProtobufUtil.toProtoTableName(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
static MasterProtos.GetTableDescriptorsRequest |
RequestConverter.buildGetTableDescriptorsRequest(List<TableName> tableNames)
Creates a protocol buffer GetTableDescriptorsRequest
|
Modifier and Type | Method and Description |
---|---|
TableName |
Store.getTableName() |
TableName |
HStore.getTableName() |
Modifier and Type | Method and Description |
---|---|
List<HRegion> |
HRegionServer.getOnlineRegions(TableName tableName)
Gets the online regions of the specified table.
|
Modifier and Type | Method and Description |
---|---|
TableName |
HLogKey.getTablename() |
Modifier and Type | Method and Description |
---|---|
void |
HLog.append(HRegionInfo info,
TableName tableName,
WALEdit edits,
long now,
HTableDescriptor htd,
AtomicLong sequenceId)
Same as appendNoSync(HRegionInfo, TableName, WALEdit, List, long, HTableDescriptor),
except it causes a sync on the log
|
long |
HLog.appendNoSync(HRegionInfo info,
TableName tableName,
WALEdit edits,
List<UUID> clusterIds,
long now,
HTableDescriptor htd,
AtomicLong sequenceId,
boolean isInMemstore,
long nonceGroup,
long nonce)
Append a set of edits to the log.
|
protected void |
HLogKey.init(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce) |
Constructor and Description |
---|
HLogKey(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long now,
List<UUID> clusterIds,
long nonceGroup,
long nonce)
Create the log key for writing to somewhere.
|
HLogKey(byte[] encodedRegionName,
TableName tablename,
long logSeqNum,
long now,
UUID clusterId) |
WALEditsReplaySink(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
HConnection conn)
Create a sink for WAL log entries replay
|
Modifier and Type | Method and Description |
---|---|
protected void |
ReplicationSink.batch(TableName tableName,
Collection<List<Row>> allRows)
Do the changes and handle the pool
|
Modifier and Type | Method and Description |
---|---|
TableName |
RemoteHTable.getName() |
Modifier and Type | Field and Description |
---|---|
static TableName |
AccessControlLists.ACL_TABLE_NAME
Internal storage table for access control lists
|
Modifier and Type | Method and Description |
---|---|
TableName |
AuthResult.getTableName() |
TableName |
TablePermission.getTableName() |
Modifier and Type | Method and Description |
---|---|
static AuthResult |
AuthResult.allow(String request,
String reason,
User user,
Permission.Action action,
TableName table,
byte[] family,
byte[] qualifier) |
static AuthResult |
AuthResult.allow(String request,
String reason,
User user,
Permission.Action action,
TableName table,
Map<byte[],? extends Collection<?>> families) |
boolean |
TableAuthManager.authorize(User user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action) |
boolean |
TableAuthManager.authorize(User user,
TableName table,
byte[] family,
Permission.Action action) |
boolean |
TableAuthManager.authorize(User user,
TableName table,
Cell cell,
Permission.Action action)
Authorize a user for a given KV.
|
boolean |
TableAuthManager.authorizeGroup(String groupName,
TableName table,
byte[] family,
Permission.Action action)
Checks authorization to a given table and column family for a group, based
on the stored permissions.
|
boolean |
TableAuthManager.authorizeUser(User user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action) |
boolean |
TableAuthManager.authorizeUser(User user,
TableName table,
byte[] family,
Permission.Action action)
Checks authorization to a given table and column family for a user, based on the
stored user permissions.
|
static AuthResult |
AuthResult.deny(String request,
String reason,
User user,
Permission.Action action,
TableName table,
byte[] family,
byte[] qualifier) |
static AuthResult |
AuthResult.deny(String request,
String reason,
User user,
Permission.Action action,
TableName table,
Map<byte[],? extends Collection<?>> families) |
static AccessControlProtos.GrantResponse |
AccessControlClient.grant(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
String userName,
byte[] family,
byte[] qual,
AccessControlProtos.Permission.Action... actions)
Grants permission on the specified table for the specified user
|
boolean |
TablePermission.implies(TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action)
Checks that a given table operation is authorized by this permission
instance.
|
boolean |
TablePermission.implies(TableName table,
KeyValue kv,
Permission.Action action)
Checks if this permission grants access to perform the given action on
the given table and key value.
|
boolean |
TablePermission.matchesFamily(TableName table,
byte[] family,
Permission.Action action)
Returns
true if this permission matches the given column
family at least. |
boolean |
TablePermission.matchesFamilyQualifier(TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action)
Returns if the given permission matches the given qualifier.
|
boolean |
TableAuthManager.matchPermission(User user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action action) |
boolean |
TableAuthManager.matchPermission(User user,
TableName table,
byte[] family,
Permission.Action action)
Returns true if the given user has a
TablePermission matching up
to the column family portion of a permission. |
void |
AccessController.postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
byte[] col) |
void |
AccessController.postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
AccessController.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
HTableDescriptor htd) |
void |
AccessController.preAddColumn(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
HColumnDescriptor column) |
void |
AccessController.preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
byte[] col) |
void |
AccessController.preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
AccessController.preDisableTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
AccessController.preEnableTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName) |
void |
AccessController.preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
HColumnDescriptor descriptor) |
void |
AccessController.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
HTableDescriptor htd) |
void |
TableAuthManager.refreshTableCacheFromWritable(TableName table,
byte[] data) |
void |
TableAuthManager.removeTable(TableName table) |
static AccessControlProtos.RevokeResponse |
AccessControlClient.revoke(org.apache.hadoop.conf.Configuration conf,
String username,
TableName tableName,
byte[] family,
byte[] qualifier,
AccessControlProtos.Permission.Action... actions)
Revokes the permission on the table
|
void |
TableAuthManager.setTableGroupPermissions(String group,
TableName table,
List<TablePermission> perms)
Overwrites the existing permission set for a group and triggers an update
for zookeeper synchronization.
|
void |
TableAuthManager.setTableUserPermissions(String username,
TableName table,
List<TablePermission> perms)
Overwrites the existing permission set for a given user for a table, and
triggers an update for zookeeper synchronization.
|
void |
TableAuthManager.writeTableToZooKeeper(TableName table,
org.apache.hadoop.hbase.security.access.TableAuthManager.PermissionCache<TablePermission> tablePerms) |
Modifier and Type | Method and Description |
---|---|
void |
AccessController.preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableName> tableNamesList,
List<HTableDescriptor> descriptors) |
Constructor and Description |
---|
AuthResult(boolean allowed,
String request,
String reason,
User user,
Permission.Action action,
TableName table,
byte[] family,
byte[] qualifier) |
AuthResult(boolean allowed,
String request,
String reason,
User user,
Permission.Action action,
TableName table,
Map<byte[],? extends Collection<?>> families) |
TablePermission(String namespace,
TableName table,
byte[] family,
byte[] qualifier,
byte[] actionCodes)
Creates a new permission for the given namespace or table, family and column qualifier,
allowing the actions matching the provided byte codes to be performed.
|
TablePermission(String namespace,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... assigned)
Creates a new permission for the given namespace or table, restricted to the given
column family and qualifer, allowing the assigned actions to be performed.
|
TablePermission(TableName table,
byte[] family,
byte[] qualifier,
byte[] actionCodes)
Creates a new permission for the given table, family and column qualifier,
allowing the actions matching the provided byte codes to be performed.
|
TablePermission(TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... assigned)
Creates a new permission for the given table, restricted to the given
column family and qualifer, allowing the assigned actions to be performed.
|
TablePermission(TableName table,
byte[] family,
Permission.Action... assigned)
Create a new permission for the given table and (optionally) column family,
allowing the given actions.
|
UserPermission(byte[] user,
TableName table,
byte[] family,
byte[] qualifier,
byte[] actionCodes)
Creates a new instance for the given user, table, column family and
qualifier, matching the actions with the given codes.
|
UserPermission(byte[] user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... assigned)
Creates a new permission for the given user, table, column family and
column qualifier.
|
UserPermission(byte[] user,
TableName table,
byte[] family,
Permission.Action... assigned)
Creates a new instance for the given user, table and column family.
|
Modifier and Type | Field and Description |
---|---|
static TableName |
VisibilityConstants.LABELS_TABLE_NAME
Internal storage table for visibility labels
|
Modifier and Type | Method and Description |
---|---|
void |
VisibilityController.preAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HColumnDescriptor column) |
void |
VisibilityController.preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
byte[] c) |
void |
VisibilityController.preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName) |
void |
VisibilityController.preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HColumnDescriptor descriptor) |
void |
VisibilityController.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HTableDescriptor htd) |
Modifier and Type | Method and Description |
---|---|
static HTableDescriptor |
RestoreSnapshotHelper.cloneTableSchema(HTableDescriptor snapshotTableDescriptor,
TableName tableName)
Create a new table descriptor cloning the snapshot table schema.
|
Constructor and Description |
---|
TablePartiallyOpenException(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
static void |
Canary.sniff(HBaseAdmin admin,
TableName tableName)
Canary entry point for specified table.
|
Modifier and Type | Method and Description |
---|---|
TableName |
HBaseFsck.TableInfo.getName() |
TableName |
HBaseFsck.HbckInfo.getTableName() |
static TableName |
FSUtils.getTableName(org.apache.hadoop.fs.Path tablePath)
Returns the
TableName object representing
the table directory under
path rootdir |
Modifier and Type | Method and Description |
---|---|
void |
FSTableDescriptors.deleteTableDescriptorIfExists(TableName tableName)
Deletes all the table descriptor files from the file system.
|
HTableDescriptor |
FSTableDescriptors.get(TableName tablename)
Get the current table descriptor for the given table, or null if none exists.
|
com.google.common.collect.Multimap<byte[],HBaseFsck.HbckInfo> |
HBaseFsck.getOverlapGroups(TableName table) |
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getRegionArchiveDir(org.apache.hadoop.fs.Path rootDir,
TableName tableName,
org.apache.hadoop.fs.Path regiondir)
Get the archive directory for a given region under the specified table
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getRegionArchiveDir(org.apache.hadoop.fs.Path rootDir,
TableName tableName,
String encodedRegionName)
Get the archive directory for a given region under the specified table
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getStoreArchivePath(org.apache.hadoop.conf.Configuration conf,
TableName tableName,
String regionName,
String familyName)
Get the directory to archive a store directory
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getTableArchivePath(org.apache.hadoop.conf.Configuration conf,
TableName tableName)
Get the path to the table archive directory based on the configured archive directory.
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getTableArchivePath(org.apache.hadoop.fs.Path rootdir,
TableName tableName)
Get the path to the table archive directory based on the configured archive directory.
|
static HTableDescriptor |
FSTableDescriptors.getTableDescriptorFromFs(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path hbaseRootDir,
TableName tableName)
Returns the latest table descriptor for the given table directly from the file system
if it exists, bypassing the local cache.
|
static org.apache.hadoop.fs.Path |
FSUtils.getTableDir(org.apache.hadoop.fs.Path rootdir,
TableName tableName)
Returns the
Path object representing the table directory under
path rootdir |
static Map<String,org.apache.hadoop.fs.Path> |
FSUtils.getTableStoreFilePathMap(Map<String,org.apache.hadoop.fs.Path> map,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path hbaseRootDir,
TableName tableName)
Runs through the HBase rootdir/tablename and creates a reverse lookup map for
table StoreFile names to the full Path.
|
void |
HBaseFsck.includeTable(TableName table) |
boolean |
FSTableDescriptors.isTableInfoExists(TableName tableName)
Checks if a current table info file exists for the given table
|
<R> void |
MultiHConnection.processBatchCallback(List<? extends Row> actions,
TableName tableName,
Object[] results,
Batch.Callback<R> callback)
Randomly pick a connection and process the batch of actions for a given table
|
HTableDescriptor |
FSTableDescriptors.remove(TableName tablename)
Removes the table descriptor from the local cache and returns it.
|
Modifier and Type | Method and Description |
---|---|
static Set<TableName> |
ZKTableReadOnly.getDisabledOrDisablingTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabled in zookeeper.
|
static Set<TableName> |
ZKTable.getDisabledOrDisablingTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabled in zookeeper.
|
Set<TableName> |
ZKTable.getDisabledTables()
Gets a list of all the tables set as disabled in zookeeper.
|
static Set<TableName> |
ZKTableReadOnly.getDisabledTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabled in zookeeper.
|
static Set<TableName> |
ZKTable.getDisabledTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabled in zookeeper.
|
static Set<TableName> |
ZKTable.getDisablingTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabling in zookeeper.
|
static Set<TableName> |
ZKTable.getEnablingTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as enabling in zookeeper.
|
Modifier and Type | Method and Description |
---|---|
boolean |
ZKTable.checkAndSetEnablingTable(TableName tableName)
Sets the specified table as ENABLING in zookeeper atomically
If the table is already in ENABLING state, no operation is performed
|
boolean |
ZKTable.checkDisabledAndSetEnablingTable(TableName tableName)
Sets the specified table as ENABLING in zookeeper atomically
If the table isn't in DISABLED state, no operation is performed
|
boolean |
ZKTable.checkEnabledAndSetDisablingTable(TableName tableName)
Sets the specified table as DISABLING in zookeeper atomically
If the table isn't in ENABLED state, no operation is performed
|
boolean |
ZKTable.isDisabledOrEnablingTable(TableName tableName) |
boolean |
ZKTable.isDisabledTable(TableName tableName) |
static boolean |
ZKTableReadOnly.isDisabledTable(ZooKeeperWatcher zkw,
TableName tableName)
Go to zookeeper and see if state of table is
ZooKeeperProtos.Table.State#DISABLED . |
boolean |
ZKTable.isDisablingOrDisabledTable(TableName tableName) |
static boolean |
ZKTableReadOnly.isDisablingOrDisabledTable(ZooKeeperWatcher zkw,
TableName tableName)
Go to zookeeper and see if state of table is
ZooKeeperProtos.Table.State#DISABLING
of ZooKeeperProtos.Table.State#DISABLED . |
boolean |
ZKTable.isDisablingTable(TableName tableName) |
boolean |
ZKTable.isEnabledOrDisablingTable(TableName tableName) |
boolean |
ZKTable.isEnabledTable(TableName tableName) |
static boolean |
ZKTableReadOnly.isEnabledTable(ZooKeeperWatcher zkw,
TableName tableName)
Go to zookeeper and see if state of table is
ZooKeeperProtos.Table.State#ENABLED . |
boolean |
ZKTable.isEnablingOrEnabledTable(TableName tableName) |
boolean |
ZKTable.isEnablingTable(TableName tableName) |
boolean |
ZKTable.isTablePresent(TableName tableName)
check if table is present .
|
void |
ZKTable.removeEnablingTable(TableName tableName,
boolean deleteZNode)
If the table is found in ENABLING state the inmemory state is removed.
|
void |
ZKTable.setDeletedTable(TableName tableName)
Deletes the table in zookeeper.
|
void |
ZKTable.setDisabledTable(TableName tableName)
Sets the specified table as DISABLED in zookeeper.
|
void |
ZKTable.setDisablingTable(TableName tableName)
Sets the specified table as DISABLING in zookeeper.
|
void |
ZKTable.setEnabledTable(TableName tableName)
Sets the ENABLED state in the cache and creates or force updates a node to
ENABLED state for the specified table
|
void |
ZKTable.setEnablingTable(TableName tableName)
Sets the specified table as ENABLING in zookeeper.
|
Copyright © 2014 The Apache Software Foundation. All rights reserved.