Uses of Interface
org.apache.hadoop.hbase.client.Table

Packages that use org.apache.hadoop.hbase.client.Table
Package
Description
 
Provides HBase Client
 
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides an HBase Thrift service.
 
  • Uses of org.apache.hadoop.hbase.client.Table in org.apache.hadoop.hbase

    Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.client.Table in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createMultiRegionTable(org.apache.hadoop.hbase.TableName tableName, byte[] family)
    Deprecated.
    Create a table with multiple regions.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createMultiRegionTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families)
    Deprecated.
    Create a table with multiple regions.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createMultiRegionTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions)
    Deprecated.
    Create a table with multiple regions.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createMultiRegionTable(org.apache.hadoop.hbase.TableName tableName, byte[] family, int numRegions)
    Deprecated.
    Create a table with multiple regions.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createMultiRegionTable(org.apache.hadoop.hbase.TableName tableName, int replicaCount, byte[][] families)
    Deprecated.
    Create a table with multiple regions.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createRandomTable(org.apache.hadoop.hbase.TableName tableName, Collection<String> families, int maxVersions, int numColsPerRow, int numFlushes, int numRegions, int numRowsPerFlush)
    Deprecated.
    Creates a random table with the given parameters
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.client.TableDescriptor htd, byte[][] splitRows)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.client.TableDescriptor htd, byte[][] families, byte[][] splitKeys, org.apache.hadoop.conf.Configuration c)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.client.TableDescriptor htd, byte[][] families, byte[][] splitKeys, org.apache.hadoop.hbase.regionserver.BloomType type, int blockSize, org.apache.hadoop.conf.Configuration c)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.client.TableDescriptor htd, byte[][] families, org.apache.hadoop.conf.Configuration c)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[] family)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, byte[][] splitKeys)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, byte[][] splitKeys, int replicaCount)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, byte[][] splitKeys, int replicaCount, org.apache.hadoop.conf.Configuration c)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int[] numVersions)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions, byte[][] splitKeys)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions, byte[] startKey, byte[] endKey, int numRegions)
    Deprecated.
     
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions, int blockSize)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[][] families, int numVersions, int blockSize, String cpName)
    Deprecated.
     
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[] family, byte[][] splitRows)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, byte[] family, int numVersions)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, String family)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.createTable(org.apache.hadoop.hbase.TableName tableName, String[] families)
    Deprecated.
    Create a table.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.deleteTableData(org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
    Provide an existing table name to truncate.
    static org.apache.hadoop.hbase.client.Table
    MetaTableAccessor.getMetaHTable(org.apache.hadoop.hbase.client.Connection connection)
    Callers should call close on the returned Table instance.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.truncateTable(org.apache.hadoop.hbase.TableName tableName)
    Deprecated.
    Truncate a table using the admin command.
    org.apache.hadoop.hbase.client.Table
    HBaseTestingUtility.truncateTable(org.apache.hadoop.hbase.TableName tableName, boolean preserveRegions)
    Deprecated.
    Truncate a table using the admin command.
    Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.client.Table in in
    Modifier and Type
    Method
    Description
    HBaseTestingUtility.checksumRows(org.apache.hadoop.hbase.client.Table table)
    Deprecated.
    Return an md5 digest of the entire contents of a table.
    static int
    HBaseTestingUtility.countRows(org.apache.hadoop.hbase.client.Table table)
    Deprecated.
    Return the number of rows in the given table.
    int
    HBaseTestingUtility.countRows(org.apache.hadoop.hbase.client.Table table, byte[]... families)
    Deprecated.
     
    static int
    HBaseTestingUtility.countRows(org.apache.hadoop.hbase.client.Table table, org.apache.hadoop.hbase.client.Scan scan)
    Deprecated.
     
    void
    HBaseTestingUtility.deleteNumericRows(org.apache.hadoop.hbase.client.Table t, byte[] f, int startRow, int endRow)
    Deprecated.
     
    void
    HBaseTestingUtility.loadNumericRows(org.apache.hadoop.hbase.client.Table t, byte[] f, int startRow, int endRow)
    Deprecated.
     
    void
    HBaseTestingUtility.loadRandomRows(org.apache.hadoop.hbase.client.Table t, byte[] f, int rowSize, int totalRows)
    Deprecated.
     
    int
    HBaseTestingUtility.loadTable(org.apache.hadoop.hbase.client.Table t, byte[] f)
    Deprecated.
    Load table with rows from 'aaa' to 'zzz'.
    int
    HBaseTestingUtility.loadTable(org.apache.hadoop.hbase.client.Table t, byte[][] f)
    Deprecated.
    Load table of multiple column families with rows from 'aaa' to 'zzz'.
    int
    HBaseTestingUtility.loadTable(org.apache.hadoop.hbase.client.Table t, byte[][] f, byte[] value)
    Deprecated.
    Load table of multiple column families with rows from 'aaa' to 'zzz'.
    int
    HBaseTestingUtility.loadTable(org.apache.hadoop.hbase.client.Table t, byte[][] f, byte[] value, boolean writeToWAL)
    Deprecated.
    Load table of multiple column families with rows from 'aaa' to 'zzz'.
    int
    HBaseTestingUtility.loadTable(org.apache.hadoop.hbase.client.Table t, byte[] f, boolean writeToWAL)
    Deprecated.
    Load table with rows from 'aaa' to 'zzz'.
    void
    HBaseTestingUtility.verifyNumericRows(org.apache.hadoop.hbase.client.Table table, byte[] f, int startRow, int endRow, int replicaId)
    Deprecated.
     
  • Uses of org.apache.hadoop.hbase.client.Table in org.apache.hadoop.hbase.client

    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.client.Table in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.Table
    TableBuilder.build()
    Create the Table instance.
    default org.apache.hadoop.hbase.client.Table
    Connection.getTable(org.apache.hadoop.hbase.TableName tableName)
    Retrieve a Table implementation for accessing a table.
    default org.apache.hadoop.hbase.client.Table
    Connection.getTable(org.apache.hadoop.hbase.TableName tableName, ExecutorService pool)
    Retrieve a Table implementation for accessing a table.
  • Uses of org.apache.hadoop.hbase.client.Table in org.apache.hadoop.hbase.client.example

    Methods in org.apache.hadoop.hbase.client.example with parameters of type org.apache.hadoop.hbase.client.Table in in
    Modifier and Type
    Method
    Description
    void
    RefreshHFilesClient.refreshHFiles(org.apache.hadoop.hbase.client.Table table)
     
  • Uses of org.apache.hadoop.hbase.client.Table in org.apache.hadoop.hbase.mapred

    Methods in org.apache.hadoop.hbase.mapred that return org.apache.hadoop.hbase.client.Table in in
    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.client.Table
    TableInputFormatBase.getTable()
    Allows subclasses to get the Table.
    Methods in org.apache.hadoop.hbase.mapred with parameters of type org.apache.hadoop.hbase.client.Table in in
    Modifier and Type
    Method
    Description
    void
    TableRecordReader.setHTable(org.apache.hadoop.hbase.client.Table htable)
     
    void
    TableRecordReaderImpl.setHTable(org.apache.hadoop.hbase.client.Table htable)
     
  • Uses of org.apache.hadoop.hbase.client.Table in org.apache.hadoop.hbase.mapreduce

    Methods in org.apache.hadoop.hbase.mapreduce that return org.apache.hadoop.hbase.client.Table in in
    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.client.Table
    TableInputFormatBase.getTable()
    Allows subclasses to get the Table.
    Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.client.Table in in
    Modifier and Type
    Method
    Description
    static void
    HFileOutputFormat2.configureIncrementalLoad(org.apache.hadoop.mapreduce.Job job, org.apache.hadoop.hbase.client.Table table, org.apache.hadoop.hbase.client.RegionLocator regionLocator)
    Configure a MapReduce Job to perform an incremental load into the given table.
    void
    TableRecordReaderImpl.setHTable(org.apache.hadoop.hbase.client.Table htable)
    Sets the HBase table.
    void
    TableRecordReader.setTable(org.apache.hadoop.hbase.client.Table table)
     
  • Uses of org.apache.hadoop.hbase.client.Table in org.apache.hadoop.hbase.thrift

    Methods in org.apache.hadoop.hbase.thrift that return org.apache.hadoop.hbase.client.Table in in
    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.client.Table
    HBaseServiceHandler.getTable(byte[] tableName)
    Creates and returns a Table instance from a given table name.
    protected org.apache.hadoop.hbase.client.Table
    HBaseServiceHandler.getTable(ByteBuffer tableName)
     
  • Uses of org.apache.hadoop.hbase.client.Table in org.apache.hadoop.hbase.util

    Methods in org.apache.hadoop.hbase.util that return org.apache.hadoop.hbase.client.Table in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.Table
    ConnectionCache.getTable(String tableName)
    Caller closes the table afterwards.