Uses of Class
org.apache.hadoop.hbase.TableName

Packages that use TableName
org.apache.hadoop.hbase   
org.apache.hadoop.hbase.catalog   
org.apache.hadoop.hbase.client Provides HBase Client 
org.apache.hadoop.hbase.client.coprocessor Provides client classes for invoking Coprocessor RPC protocols 
org.apache.hadoop.hbase.coprocessor Table of Contents 
org.apache.hadoop.hbase.io   
org.apache.hadoop.hbase.ipc Tools to help define network clients and servers. 
org.apache.hadoop.hbase.mapred Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility 
org.apache.hadoop.hbase.mapreduce Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility 
org.apache.hadoop.hbase.master   
org.apache.hadoop.hbase.master.balancer   
org.apache.hadoop.hbase.master.handler   
org.apache.hadoop.hbase.master.snapshot   
org.apache.hadoop.hbase.protobuf Holds classes generated from protobuf src/main/protobuf definition files. 
org.apache.hadoop.hbase.regionserver   
org.apache.hadoop.hbase.regionserver.wal   
org.apache.hadoop.hbase.rest.client   
org.apache.hadoop.hbase.security.access   
org.apache.hadoop.hbase.snapshot   
org.apache.hadoop.hbase.tool   
org.apache.hadoop.hbase.util   
org.apache.hadoop.hbase.zookeeper   
 

Uses of TableName in org.apache.hadoop.hbase
 

Fields in org.apache.hadoop.hbase declared as TableName
static TableName TableName.META_TABLE_NAME
          The META table's name.
static TableName TableName.NAMESPACE_TABLE_NAME
          The Namespace table's name.
static TableName TableName.ROOT_TABLE_NAME
          The root table's name.
 

Methods in org.apache.hadoop.hbase that return TableName
 TableName HTableDescriptor.getTableName()
          Get the name of the table
 TableName HRegionInfo.getTableName()
          Get current table name of the region
static TableName HRegionInfo.getTableName(byte[] regionName)
          Gets the table name from the specified region name.
static TableName TableName.valueOf(byte[] name)
           
static TableName TableName.valueOf(byte[] namespace, byte[] qualifier)
           
static TableName TableName.valueOf(String name)
           
static TableName TableName.valueOf(String namespaceAsString, String qualifierAsString)
           
 

Methods in org.apache.hadoop.hbase with parameters of type TableName
 int TableName.compareTo(TableName tableName)
           
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)
           
static KeyValue.KeyComparator KeyValue.getRowComparator(TableName tableName)
          Get the appropriate row comparator for the specified table.
 HTableInterface CoprocessorEnvironment.getTable(TableName tableName)
           
static boolean HTableDescriptor.isSystemTable(TableName tableName)
          Checks of the tableName being passed is a system table
 HTableDescriptor TableDescriptors.remove(TableName tablename)
           
 void HTableDescriptor.setName(TableName name)
          Deprecated. 
 

Constructors in org.apache.hadoop.hbase with parameters of type TableName
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, .META. and -ROOT-.
HTableDescriptor(TableName name, HColumnDescriptor[] families, Map<ImmutableBytesWritable,ImmutableBytesWritable> values)
           INTERNAL Private constructor used internally creating table descriptors for catalog tables, .META. and -ROOT-.
TableExistsException(TableName t)
           
TableNotDisabledException(TableName tableName)
           
TableNotEnabledException(TableName tableName)
           
TableNotFoundException(TableName tableName)
           
 

Uses of TableName in org.apache.hadoop.hbase.catalog
 

Methods in org.apache.hadoop.hbase.catalog with parameters of type TableName
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.
 

Method parameters in org.apache.hadoop.hbase.catalog with type arguments of type TableName
static Map<HRegionInfo,ServerName> MetaReader.fullScan(CatalogTracker catalogTracker, Set<TableName> disabledTables)
          Performs a full scan of .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 .META., skipping regions from any tables in the specified set of disabled tables.
 

Uses of TableName in org.apache.hadoop.hbase.client
 

Methods in org.apache.hadoop.hbase.client that return TableName
 TableName HTableInterface.getName()
          Gets the fully qualified table name instance of this table.
 TableName HTable.getName()
           
 TableName RegionServerCallable.getTableName()
           
protected  TableName ClientScanner.getTableName()
           
 TableName[] HConnectionWrapper.listTableNames()
           
 TableName[] HConnection.listTableNames()
           
 TableName[] HBaseAdmin.listTableNames()
          List all of the names of userspace tables.
 TableName[] HBaseAdmin.listTableNamesByNamespace(String name)
          Get list of table names by namespace
 

Methods in org.apache.hadoop.hbase.client with parameters of type TableName
 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 HConnectionWrapper.clearRegionCache(TableName tableName)
           
 void HConnection.clearRegionCache(TableName tableName)
          Allows flushing the region cache of all locations that pertain to 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.
 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 HConnectionWrapper.getHTableDescriptor(TableName tableName)
           
 HTableDescriptor HConnection.getHTableDescriptor(TableName tableName)
           
static boolean HTable.getRegionCachePrefetch(org.apache.hadoop.conf.Configuration conf, TableName tableName)
           
static boolean HTable.getRegionCachePrefetch(TableName tableName)
           
 boolean HConnectionWrapper.getRegionCachePrefetch(TableName tableName)
           
 boolean HConnection.getRegionCachePrefetch(TableName tableName)
          Check whether region cache prefetch is enabled or not.
 HRegionLocation HConnectionWrapper.getRegionLocation(TableName tableName, byte[] row, boolean reload)
           
 HRegionLocation HConnection.getRegionLocation(TableName tableName, byte[] row, boolean reload)
          Find region location hosting passed row
 HTableInterface HConnectionWrapper.getTable(TableName tableName)
           
 HTableInterface HConnection.getTable(TableName tableName)
          Retrieve an HTableInterface implementation for access to a table.
 HTableInterface HConnectionWrapper.getTable(TableName tableName, ExecutorService pool)
           
 HTableInterface HConnection.getTable(TableName tableName, ExecutorService pool)
          Retrieve an HTableInterface implementation for access to a table.
 HTableDescriptor HBaseAdmin.getTableDescriptor(TableName tableName)
          Method for getting the tableDescriptor
 List<HRegionInfo> HBaseAdmin.getTableRegions(TableName tableName)
          get the regions of a given table.
 boolean HConnectionWrapper.isTableAvailable(TableName tableName)
           
 boolean HConnection.isTableAvailable(TableName tableName)
           
 boolean HBaseAdmin.isTableAvailable(TableName tableName)
           
 boolean HConnectionWrapper.isTableAvailable(TableName tableName, byte[][] splitKeys)
           
 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 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 HConnectionWrapper.isTableDisabled(TableName tableName)
           
 boolean HConnection.isTableDisabled(TableName tableName)
           
 boolean HBaseAdmin.isTableDisabled(TableName tableName)
           
static boolean HTable.isTableEnabled(org.apache.hadoop.conf.Configuration conf, TableName tableName)
          Deprecated. use HBaseAdmin.isTableEnabled(org.apache.hadoop.hbase.TableName tableName)
static boolean HTable.isTableEnabled(TableName tableName)
          Deprecated. use HBaseAdmin.isTableEnabled(byte[])
 boolean HConnectionWrapper.isTableEnabled(TableName tableName)
           
 boolean HConnection.isTableEnabled(TableName tableName)
          A table that isTableEnabled == false and isTableDisabled == false is possible.
 boolean HBaseAdmin.isTableEnabled(TableName tableName)
           
 HRegionLocation HConnectionWrapper.locateRegion(TableName tableName, byte[] row)
           
 HRegionLocation HConnection.locateRegion(TableName tableName, byte[] row)
          Find the location of the region of tableName that row lives in.
 List<HRegionLocation> HConnectionWrapper.locateRegions(TableName tableName)
           
 List<HRegionLocation> HConnection.locateRegions(TableName tableName)
          Gets the locations of all regions in the specified table, tableName.
 List<HRegionLocation> HConnectionWrapper.locateRegions(TableName tableName, boolean useCache, boolean offlined)
           
 List<HRegionLocation> HConnection.locateRegions(TableName tableName, boolean useCache, boolean offlined)
          Gets the locations of all regions in the specified table, tableName.
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 HConnectionWrapper.processBatch(List<? extends Row> actions, TableName tableName, ExecutorService pool, Object[] results)
           
 void HConnection.processBatch(List<? extends Row> actions, TableName tableName, ExecutorService pool, Object[] results)
          Deprecated. since 0.96 - Use HTableInterface.batch(java.util.List, java.lang.Object[]) instead
<R> void
HConnectionWrapper.processBatchCallback(List<? extends Row> list, TableName tableName, ExecutorService pool, Object[] results, Batch.Callback<R> callback)
           
<R> void
HConnection.processBatchCallback(List<? extends Row> list, TableName tableName, ExecutorService pool, Object[] results, Batch.Callback<R> callback)
          Deprecated. since 0.96 - Use HTableInterface.batchCallback(java.util.List, java.lang.Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead
 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 HConnectionWrapper.relocateRegion(TableName tableName, byte[] row)
           
 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.
static void HTable.setRegionCachePrefetch(org.apache.hadoop.conf.Configuration conf, TableName tableName, boolean enable)
           
static void HTable.setRegionCachePrefetch(TableName tableName, boolean enable)
           
 void HConnectionWrapper.setRegionCachePrefetch(TableName tableName, boolean enable)
           
 void HConnection.setRegionCachePrefetch(TableName tableName, boolean enable)
          Enable or disable region cache prefetch for the table.
 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 HConnectionWrapper.updateCachedLocations(TableName tableName, byte[] rowkey, Object exception, HRegionLocation source)
           
 void HConnection.updateCachedLocations(TableName tableName, byte[] rowkey, Object exception, HRegionLocation source)
          Update the location cache.
 

Method parameters in org.apache.hadoop.hbase.client with type arguments of type TableName
 HTableDescriptor[] HConnectionWrapper.getHTableDescriptorsByTableName(List<TableName> tableNames)
           
 HTableDescriptor[] HConnection.getHTableDescriptorsByTableName(List<TableName> tableNames)
           
 HTableDescriptor[] HBaseAdmin.getTableDescriptorsByTableName(List<TableName> tableNames)
          Get tableDescriptors
 

Constructors in org.apache.hadoop.hbase.client with parameters of type TableName
ClientScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, TableName tableName)
          Create a new ClientScanner for the specified table.
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)
          Create a new ClientScanner 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, ExecutorService pool)
          Creates an object to access a HBase table.
MetaScanner.TableMetaScannerVisitor(TableName tableName)
           
RegionServerCallable(HConnection connection, TableName tableName, byte[] row)
           
ScannerCallable(HConnection connection, TableName tableName, Scan scan, ScanMetrics scanMetrics)
           
 

Uses of TableName in org.apache.hadoop.hbase.client.coprocessor
 

Methods in org.apache.hadoop.hbase.client.coprocessor with parameters of type TableName
 String SecureBulkLoadClient.prepareBulkLoad(TableName tableName)
           
 

Uses of TableName in org.apache.hadoop.hbase.coprocessor
 

Methods in org.apache.hadoop.hbase.coprocessor with parameters of type TableName
 HTableInterface CoprocessorHost.Environment.getTable(TableName tableName)
          Open a table from within the Coprocessor environment
 void MasterObserver.postAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor column)
          Called after the new column family has been created.
 void BaseMasterObserver.postAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor column)
           
 void MasterObserver.postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor column)
          Called after the new column family has been created.
 void BaseMasterObserver.postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor column)
           
 void MasterObserver.postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] c)
          Called after the column family has been deleted.
 void BaseMasterObserver.postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] c)
           
 void MasterObserver.postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] c)
          Called after the column family has been deleted.
 void BaseMasterObserver.postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] c)
           
 void MasterObserver.postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
          Called after the deleteTable operation has been requested.
 void BaseMasterObserver.postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
           
 void MasterObserver.postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
          Called after HMaster deletes a table.
 void BaseMasterObserver.postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
           
 void MasterObserver.postDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
          Called after the disableTable operation has been requested.
 void BaseMasterObserver.postDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
           
 void MasterObserver.postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
          Called after the disableTable operation has been requested.
 void BaseMasterObserver.postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
           
 void MasterObserver.postEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
          Called after the enableTable operation has been requested.
 void BaseMasterObserver.postEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
           
 void MasterObserver.postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
          Called after the enableTable operation has been requested.
 void BaseMasterObserver.postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
           
 void MasterObserver.postModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor descriptor)
          Called after the column family has been updated.
 void BaseMasterObserver.postModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor descriptor)
           
 void MasterObserver.postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor descriptor)
          Called after the column family has been updated.
 void BaseMasterObserver.postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor descriptor)
           
 void MasterObserver.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HTableDescriptor htd)
          Called after the modifyTable operation has been requested.
 void BaseMasterObserver.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HTableDescriptor htd)
           
 void MasterObserver.postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HTableDescriptor htd)
          Called after to modifying a table's properties.
 void BaseMasterObserver.postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HTableDescriptor htd)
           
 void MasterObserver.preAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor column)
          Called prior to adding a new column family to the table.
 void BaseMasterObserver.preAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor column)
           
 void MasterObserver.preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor column)
          Called prior to adding a new column family to the table.
 void BaseMasterObserver.preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor column)
           
 void MasterObserver.preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] c)
          Called prior to deleting the entire column family.
 void BaseMasterObserver.preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] c)
           
 void MasterObserver.preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] c)
          Called prior to deleting the entire column family.
 void BaseMasterObserver.preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] c)
           
 void MasterObserver.preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
          Called before HMaster deletes a table.
 void BaseMasterObserver.preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
           
 void MasterObserver.preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
          Called before HMaster deletes a table.
 void BaseMasterObserver.preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
           
 void MasterObserver.preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
          Called prior to disabling a table.
 void BaseMasterObserver.preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
           
 void MasterObserver.preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
          Called prior to disabling a table.
 void BaseMasterObserver.preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
           
 void MasterObserver.preEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
          Called prior to enabling a table.
 void BaseMasterObserver.preEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
           
 void MasterObserver.preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
          Called prior to enabling a table.
 void BaseMasterObserver.preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName)
           
 void MasterObserver.preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor descriptor)
          Called prior to modifying a column family's attributes.
 void BaseMasterObserver.preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor descriptor)
           
 void MasterObserver.preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor descriptor)
          Called prior to modifying a column family's attributes.
 void BaseMasterObserver.preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor descriptor)
           
 void MasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HTableDescriptor htd)
          Called prior to modifying a table's properties.
 void BaseMasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HTableDescriptor htd)
           
 void MasterObserver.preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HTableDescriptor htd)
          Called prior to modifying a table's properties.
 void BaseMasterObserver.preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HTableDescriptor htd)
           
 

Method parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type TableName
 void MasterObserver.preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableName> tableNamesList, List<HTableDescriptor> descriptors)
          Called before a getTableDescriptors request has been processed.
 void BaseMasterObserver.preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableName> tableNamesList, List<HTableDescriptor> descriptors)
           
 

Uses of TableName in org.apache.hadoop.hbase.io
 

Methods in org.apache.hadoop.hbase.io that return TableName
static TableName HFileLink.getReferencedTableName(String fileName)
          Get the Table name of the referenced link
 

Methods in org.apache.hadoop.hbase.io with parameters of type TableName
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 String HFileLink.createHFileLinkName(TableName tableName, String regionName, String hfileName)
          Create a new HFileLink name
 

Uses of TableName in org.apache.hadoop.hbase.ipc
 

Constructors in org.apache.hadoop.hbase.ipc with parameters of type TableName
RegionCoprocessorRpcChannel(HConnection conn, TableName table, byte[] row)
           
 

Uses of TableName in org.apache.hadoop.hbase.mapred
 

Methods in org.apache.hadoop.hbase.mapred that return TableName
 TableName TableSplit.getTable()
          Deprecated.  
 

Constructors in org.apache.hadoop.hbase.mapred with parameters of type TableName
TableSplit(TableName tableName, byte[] startRow, byte[] endRow, String location)
          Deprecated. Constructor
 

Uses of TableName in org.apache.hadoop.hbase.mapreduce
 

Methods in org.apache.hadoop.hbase.mapreduce that return TableName
 TableName TableSplit.getTableName()
          Returns the table name.
 

Methods in org.apache.hadoop.hbase.mapreduce with parameters of type TableName
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.
 

Constructors in org.apache.hadoop.hbase.mapreduce with parameters of type TableName
TableSplit(TableName tableName, byte[] startRow, byte[] endRow, String location)
          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.
 

Uses of TableName in org.apache.hadoop.hbase.master
 

Methods in org.apache.hadoop.hbase.master that return types with arguments of type TableName
protected  Map<TableName,Map<ServerName,List<HRegionInfo>>> RegionStates.getAssignmentsByTable()
          This is an EXPENSIVE clone.
 List<TableName> MasterServices.listTableNamesByNamespace(String name)
          Get list of table names by namespace
 List<TableName> HMaster.listTableNamesByNamespace(String name)
           
 

Methods in org.apache.hadoop.hbase.master with parameters of type TableName
 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.addColumn(TableName tableName, HColumnDescriptor column)
           
 void MasterServices.checkTableModifiable(TableName tableName)
          Check table is modifiable; i.e.
 void HMaster.checkTableModifiable(TableName tableName)
           
 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.deleteColumn(TableName tableName, byte[] columnName)
           
 void MasterServices.deleteTable(TableName tableName)
          Delete a table
 void MasterFileSystem.deleteTable(TableName tableName)
           
 void HMaster.deleteTable(TableName tableName)
           
 void MasterServices.disableTable(TableName tableName)
          Disable an existing table
 void HMaster.disableTable(TableName tableName)
           
 void MasterServices.enableTable(TableName tableName)
          Enable an existing table
 void HMaster.enableTable(TableName tableName)
           
 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 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.modifyColumn(TableName tableName, HColumnDescriptor descriptor)
           
 void MasterServices.modifyTable(TableName tableName, HTableDescriptor descriptor)
          Modify the descriptor of an existing table
 void HMaster.modifyTable(TableName tableName, HTableDescriptor descriptor)
           
 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.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)
           
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)
           
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)
           
 

Method parameters in org.apache.hadoop.hbase.master with type arguments of type TableName
 boolean MasterCoprocessorHost.preGetTableDescriptors(List<TableName> tableNamesList, List<HTableDescriptor> descriptors)
           
 

Uses of TableName in org.apache.hadoop.hbase.master.balancer
 

Method parameters in org.apache.hadoop.hbase.master.balancer with type arguments of type TableName
static Map<HRegionInfo,ServerName> FavoredNodeAssignmentHelper.fullScan(CatalogTracker catalogTracker, Set<TableName> disabledTables, boolean excludeOfflinedSplitParents, FavoredNodeLoadBalancer balancer)
          Perform full scan of the meta table similar to MetaReader.fullScan(CatalogTracker, Set, boolean) except that this is aware of the favored nodes
 

Uses of TableName in org.apache.hadoop.hbase.master.handler
 

Fields in org.apache.hadoop.hbase.master.handler declared as TableName
protected  TableName TableEventHandler.tableName
           
 

Methods in org.apache.hadoop.hbase.master.handler with parameters of type TableName
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.
 

Constructors in org.apache.hadoop.hbase.master.handler with parameters of type TableName
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)
           
 

Uses of TableName in org.apache.hadoop.hbase.master.snapshot
 

Fields in org.apache.hadoop.hbase.master.snapshot declared as TableName
protected  TableName TakeSnapshotHandler.snapshotTable
           
 

Methods in org.apache.hadoop.hbase.master.snapshot with parameters of type TableName
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
 

Uses of TableName in org.apache.hadoop.hbase.protobuf
 

Methods in org.apache.hadoop.hbase.protobuf that return TableName
static TableName[] ProtobufUtil.getTableNameArray(List<HBaseProtos.TableName> tableNamesList)
           
static TableName ProtobufUtil.toTableName(HBaseProtos.TableName tableNamePB)
           
 

Methods in org.apache.hadoop.hbase.protobuf with parameters of type TableName
static MasterAdminProtos.AddColumnRequest RequestConverter.buildAddColumnRequest(TableName tableName, HColumnDescriptor column)
          Create a protocol buffer AddColumnRequest
static MasterAdminProtos.DeleteColumnRequest RequestConverter.buildDeleteColumnRequest(TableName tableName, byte[] columnName)
          Create a protocol buffer DeleteColumnRequest
static MasterAdminProtos.DeleteTableRequest RequestConverter.buildDeleteTableRequest(TableName tableName)
          Creates a protocol buffer DeleteTableRequest
static MasterAdminProtos.DisableTableRequest RequestConverter.buildDisableTableRequest(TableName tableName)
          Creates a protocol buffer DisableTableRequest
static MasterAdminProtos.EnableTableRequest RequestConverter.buildEnableTableRequest(TableName tableName)
          Creates a protocol buffer EnableTableRequest
static MasterMonitorProtos.GetSchemaAlterStatusRequest RequestConverter.buildGetSchemaAlterStatusRequest(TableName tableName)
          Creates a protocol buffer GetSchemaAlterStatusRequest
static MasterMonitorProtos.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 MasterAdminProtos.ModifyColumnRequest RequestConverter.buildModifyColumnRequest(TableName tableName, HColumnDescriptor column)
          Create a protocol buffer ModifyColumnRequest
static MasterAdminProtos.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)
           
 

Method parameters in org.apache.hadoop.hbase.protobuf with type arguments of type TableName
static MasterMonitorProtos.GetTableDescriptorsRequest RequestConverter.buildGetTableDescriptorsRequest(List<TableName> tableNames)
          Creates a protocol buffer GetTableDescriptorsRequest
 

Uses of TableName in org.apache.hadoop.hbase.regionserver
 

Methods in org.apache.hadoop.hbase.regionserver that return TableName
 TableName Store.getTableName()
           
 TableName HStore.getTableName()
           
 

Methods in org.apache.hadoop.hbase.regionserver with parameters of type TableName
 List<HRegion> HRegionServer.getOnlineRegions(TableName tableName)
          Gets the online regions of the specified table.
 

Uses of TableName in org.apache.hadoop.hbase.regionserver.wal
 

Methods in org.apache.hadoop.hbase.regionserver.wal that return TableName
 TableName HLogKey.getTablename()
           
 

Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type TableName
 void HLog.append(HRegionInfo info, TableName tableName, WALEdit edits, long now, HTableDescriptor htd)
          Same as HLog.appendNoSync(HRegionInfo, TableName, WALEdit, UUID, long, HTableDescriptor), except it causes a sync on the log
 void HLog.append(HRegionInfo info, TableName tableName, WALEdit edits, long now, HTableDescriptor htd, boolean isInMemstore)
          Append a set of edits to the log.
 long HLog.appendNoSync(HRegionInfo info, TableName tableName, WALEdit edits, UUID clusterId, long now, HTableDescriptor htd)
          Append a set of edits to the log.
 

Constructors in org.apache.hadoop.hbase.regionserver.wal with parameters of type TableName
HLogKey(byte[] encodedRegionName, TableName tablename, long logSeqNum, long now, UUID clusterId)
          Create the log key for writing to somewhere.
WALEditsReplaySink(org.apache.hadoop.conf.Configuration conf, TableName tableName, HConnection conn)
          Create a sink for WAL log entries replay
 

Uses of TableName in org.apache.hadoop.hbase.rest.client
 

Methods in org.apache.hadoop.hbase.rest.client that return TableName
 TableName RemoteHTable.getName()
           
 

Uses of TableName in org.apache.hadoop.hbase.security.access
 

Fields in org.apache.hadoop.hbase.security.access declared as TableName
static TableName AccessControlLists.ACL_TABLE_NAME
          Internal storage table for access control lists
 

Methods in org.apache.hadoop.hbase.security.access that return TableName
 TableName TablePermission.getTable()
           
 TableName AuthResult.getTableName()
           
 

Methods in org.apache.hadoop.hbase.security.access with parameters of type TableName
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, KeyValue kv, Permission.Action action)
           
 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(String username, TableName table, byte[] family, byte[] qualifier, Permission.Action action)
           
 boolean TableAuthManager.authorizeUser(String username, 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)
           
 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.postAddColumn(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, HColumnDescriptor column)
           
 void AccessController.postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, HColumnDescriptor column)
           
 void AccessController.postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, byte[] col)
           
 void AccessController.postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, byte[] col)
           
 void AccessController.postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName)
           
 void AccessController.postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName)
           
 void AccessController.postDisableTable(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName)
           
 void AccessController.postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName)
           
 void AccessController.postEnableTable(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName)
           
 void AccessController.postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName)
           
 void AccessController.postModifyColumn(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, HColumnDescriptor descriptor)
           
 void AccessController.postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, HColumnDescriptor descriptor)
           
 void AccessController.postModifyTable(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, HTableDescriptor htd)
           
 void AccessController.postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, HTableDescriptor htd)
           
 void AccessController.preAddColumn(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, HColumnDescriptor column)
           
 void AccessController.preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, HColumnDescriptor column)
           
 void AccessController.preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, byte[] col)
           
 void AccessController.preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, byte[] col)
           
 void AccessController.preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName)
           
 void AccessController.preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName)
           
 void AccessController.preDisableTable(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName)
           
 void AccessController.preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName)
           
 void AccessController.preEnableTable(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName)
           
 void AccessController.preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName)
           
 void AccessController.preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, HColumnDescriptor descriptor)
           
 void AccessController.preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, HColumnDescriptor descriptor)
           
 void AccessController.preModifyTable(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, HTableDescriptor htd)
           
 void AccessController.preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, HTableDescriptor htd)
           
 void TableAuthManager.refreshTableCacheFromWritable(TableName table, byte[] data)
           
 void TableAuthManager.removeTable(TableName 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)
           
 

Method parameters in org.apache.hadoop.hbase.security.access with type arguments of type TableName
 void AccessController.preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableName> tableNamesList, List<HTableDescriptor> descriptors)
           
 

Constructors in org.apache.hadoop.hbase.security.access with parameters of type TableName
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.
 

Uses of TableName in org.apache.hadoop.hbase.snapshot
 

Methods in org.apache.hadoop.hbase.snapshot with parameters of type TableName
static HTableDescriptor RestoreSnapshotHelper.cloneTableSchema(HTableDescriptor snapshotTableDescriptor, TableName tableName)
          Create a new table descriptor cloning the snapshot table schema.
 

Constructors in org.apache.hadoop.hbase.snapshot with parameters of type TableName
TablePartiallyOpenException(TableName tableName)
           
 

Uses of TableName in org.apache.hadoop.hbase.tool
 

Methods in org.apache.hadoop.hbase.tool with parameters of type TableName
static void Canary.sniff(HBaseAdmin admin, TableName tableName)
          Canary entry point for specified table.
 

Uses of TableName in org.apache.hadoop.hbase.util
 

Methods in org.apache.hadoop.hbase.util that return TableName
 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
 

Methods in org.apache.hadoop.hbase.util with parameters of type TableName
 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
 HTableDescriptor FSTableDescriptors.remove(TableName tablename)
          Removes the table descriptor from the local cache and returns it.
 

Uses of TableName in org.apache.hadoop.hbase.zookeeper
 

Methods in org.apache.hadoop.hbase.zookeeper that return types with arguments of type TableName
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.
 

Methods in org.apache.hadoop.hbase.zookeeper with parameters of type TableName
 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.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 © 2013 The Apache Software Foundation. All Rights Reserved.