Uses of Interface
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.
Multi Cluster Replication
HBase REST
Provides an HBase Thrift
service.
Provides an HBase Thrift
service.
This package provides fully-functional exemplar Java code demonstrating
simple usage of the hbase-client API, for incorporation into a Maven
archetype with hbase-client dependency.
This package provides fully-functional exemplar Java code demonstrating
simple usage of the hbase-client API, for incorporation into a Maven
archetype with hbase-shaded-client dependency.
-
Uses of Table in org.apache.hadoop.hbase
Modifier and TypeFieldDescriptionprotected Table
PerformanceEvaluation.BufferedMutatorTest.table
protected Table
PerformanceEvaluation.TableTest.table
Modifier and TypeMethodDescriptionHBaseTestingUtility.createMultiRegionTable
(TableName tableName, byte[] family) Deprecated.Create a table with multiple regions.HBaseTestingUtility.createMultiRegionTable
(TableName tableName, byte[][] families) Deprecated.Create a table with multiple regions.HBaseTestingUtility.createMultiRegionTable
(TableName tableName, byte[][] families, int numVersions) Deprecated.Create a table with multiple regions.HBaseTestingUtility.createMultiRegionTable
(TableName tableName, byte[] family, int numRegions) Deprecated.Create a table with multiple regions.HBaseTestingUtility.createMultiRegionTable
(TableName tableName, int replicaCount, byte[][] families) Deprecated.Create a table with multiple regions.HBaseTestingUtility.createRandomTable
(TableName tableName, Collection<String> families, int maxVersions, int numColsPerRow, int numFlushes, int numRegions, int numRowsPerFlush) Deprecated.Creates a random table with the given parametersHBaseTestingUtility.createTable
(TableDescriptor htd, byte[][] splitRows) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableDescriptor htd, byte[][] families, byte[][] splitKeys, org.apache.hadoop.conf.Configuration c) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableDescriptor htd, byte[][] families, byte[][] splitKeys, BloomType type, int blockSize, org.apache.hadoop.conf.Configuration c) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableDescriptor htd, byte[][] families, org.apache.hadoop.conf.Configuration c) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableName tableName, byte[] family) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableName tableName, byte[][] families) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableName tableName, byte[][] families, byte[][] splitKeys) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableName tableName, byte[][] families, byte[][] splitKeys, int replicaCount) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableName tableName, byte[][] families, byte[][] splitKeys, int replicaCount, org.apache.hadoop.conf.Configuration c) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableName tableName, byte[][] families, int numVersions) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableName tableName, byte[][] families, int[] numVersions) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableName tableName, byte[][] families, int numVersions, byte[][] splitKeys) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableName tableName, byte[][] families, int numVersions, byte[] startKey, byte[] endKey, int numRegions) Deprecated.HBaseTestingUtility.createTable
(TableName tableName, byte[][] families, int numVersions, int blockSize) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableName tableName, byte[][] families, int numVersions, int blockSize, String cpName) Deprecated.HBaseTestingUtility.createTable
(TableName tableName, byte[] family, byte[][] splitRows) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableName tableName, byte[] family, int numVersions) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableName tableName, String family) Deprecated.Create a table.HBaseTestingUtility.createTable
(TableName tableName, String[] families) Deprecated.Create a table.HBaseTestingUtility.deleteTableData
(TableName tableName) Deprecated.Provide an existing table name to truncate.static Table
MetaTableAccessor.getMetaHTable
(Connection connection) Callers should call close on the returnedTable
instance.HBaseTestingUtility.truncateTable
(TableName tableName) Deprecated.Truncate a table using the admin command.HBaseTestingUtility.truncateTable
(TableName tableName, boolean preserveRegions) Deprecated.Truncate a table using the admin command.Modifier and TypeMethodDescriptionHBaseTestingUtility.checksumRows
(Table table) Deprecated.Return an md5 digest of the entire contents of a table.static int
Deprecated.Return the number of rows in the given table.int
Deprecated.static int
Deprecated.void
HBaseTestingUtility.deleteNumericRows
(Table t, byte[] f, int startRow, int endRow) Deprecated.void
HBaseTestingUtility.loadNumericRows
(Table t, byte[] f, int startRow, int endRow) Deprecated.void
HBaseTestingUtility.loadRandomRows
(Table t, byte[] f, int rowSize, int totalRows) Deprecated.int
Deprecated.Load table with rows from 'aaa' to 'zzz'.int
Deprecated.Load table of multiple column families with rows from 'aaa' to 'zzz'.int
Deprecated.Load table of multiple column families with rows from 'aaa' to 'zzz'.int
Deprecated.Load table of multiple column families with rows from 'aaa' to 'zzz'.int
Deprecated.Load table with rows from 'aaa' to 'zzz'.private static void
void
HBaseTestingUtility.verifyNumericRows
(Table table, byte[] f, int startRow, int endRow, int replicaId) Deprecated. -
Uses of Table in org.apache.hadoop.hbase.client
Modifier and TypeClassDescription(package private) class
The table implementation based onAsyncTable
. -
Uses of Table in org.apache.hadoop.hbase.client.example
-
Uses of Table in org.apache.hadoop.hbase.mapred
Modifier and TypeFieldDescriptionprivate Table
TableRecordReaderImpl.htable
private Table
TableInputFormatBase.table
-
Uses of Table in org.apache.hadoop.hbase.mapreduce
Modifier and TypeFieldDescriptionprivate Table
TableRecordReaderImpl.htable
(package private) Table
SyncTable.SyncMapper.sourceTable
private Table
TableInputFormatBase.table
TheTable
to scan.(package private) Table
SyncTable.SyncMapper.targetTable
Modifier and TypeMethodDescriptionprotected Table
TableInputFormatBase.getTable()
Allows subclasses to get theTable
.private static Table
SyncTable.SyncMapper.openTable
(Connection connection, org.apache.hadoop.conf.Configuration conf, String tableNameConfKey) Modifier and TypeMethodDescriptionstatic void
HFileOutputFormat2.configureIncrementalLoad
(org.apache.hadoop.mapreduce.Job job, Table table, RegionLocator regionLocator) Configure a MapReduce Job to perform an incremental load into the given table.void
Sets the HBase table.void
-
Uses of Table in org.apache.hadoop.hbase.mapreduce.replication
Modifier and TypeFieldDescriptionprivate Table
VerifyReplication.Verifier.replicatedTable
private final Table
VerifyReplicationRecompareRunnable.replicatedTable
private Table
VerifyReplication.Verifier.sourceTable
private final Table
VerifyReplicationRecompareRunnable.sourceTable
ModifierConstructorDescriptionVerifyReplicationRecompareRunnable
(org.apache.hadoop.mapreduce.Mapper.Context context, Result sourceResult, Result replicatedResult, VerifyReplication.Verifier.Counters originalCounter, String delimiter, Scan tableScan, Table sourceTable, Table replicatedTable, int reCompareTries, int sleepMsBeforeReCompare, int reCompareBackoffExponent, boolean verbose) -
Uses of Table in org.apache.hadoop.hbase.master.assignment
-
Uses of Table in org.apache.hadoop.hbase.quotas
Modifier and TypeMethodDescription(package private) long
FileArchiverNotifierImpl.getPreviousNamespaceSnapshotSize
(Table quotaTable, String namespace) Fetches the current size of all snapshots in the givennamespace
.(package private) void
FileArchiverNotifierImpl.persistSnapshotSizes
(Table table, List<FileArchiverNotifierImpl.SnapshotWithSize> snapshotSizes) Writes the snapshot sizes to the providedtable
. -
Uses of Table in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionprivate Map<String,
ReplicationGroupOffset> TableReplicationQueueStorage.getOffsets0
(Table table, ReplicationQueueId queueId) private void
TableReplicationQueueStorage.listAllQueueIds
(Table table, String peerId, ServerName serverName, List<ReplicationQueueId> queueIds) private void
TableReplicationQueueStorage.listAllQueueIds
(Table table, Scan scan, List<ReplicationQueueId> queueIds) -
Uses of Table in org.apache.hadoop.hbase.rest
-
Uses of Table in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionprivate static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.addUserEntry
(Table t, String user, byte[] entry) (package private) static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.addUserGlobalHdfsAcl
(Table aclTable, String user) (package private) static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.addUserNamespaceHdfsAcl
(Table aclTable, String user, String namespace) (package private) static void
PermissionStorage.addUserPermission
(org.apache.hadoop.conf.Configuration conf, UserPermission userPerm, Table t) static void
PermissionStorage.addUserPermission
(org.apache.hadoop.conf.Configuration conf, UserPermission userPerm, Table t, boolean mergeExistingPermissions) Stores a new user permission grant in the access control lists table.(package private) static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.addUserTableHdfsAcl
(Table aclTable, String user, TableName tableName) private static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteEntry
(Table aclTable, byte[] entry) (package private) static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteTableHdfsAcl
(Table aclTable, TableName tableName) private static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteUserEntry
(Table aclTable, String user, byte[] entry) (package private) static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteUserGlobalHdfsAcl
(Table aclTable, String user) (package private) static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteUserNamespaceHdfsAcl
(Table aclTable, String user, String namespace) (package private) static void
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.deleteUserTableHdfsAcl
(Table aclTable, String user, TableName tableName) SnapshotScannerHDFSAclController.filterUsersToRemoveNsAccessAcl
(Table aclTable, TableName tableName, Set<String> tablesUsers) Remove table user access HDFS acl from namespace directory if the user has no permissions of global, ns of the table or other tables of the ns, eg: Bob has 'ns1:t1' read permission, when delete 'ns1:t1', if Bob has global read permission, '@ns1' read permission or 'ns1:other_tables' read permission, then skip remove Bob access acl in ns1Dirs, otherwise, remove Bob access acl.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.getEntryUsers
(Table aclTable, byte[] entry) (package private) static org.apache.hbase.thirdparty.com.google.common.collect.ListMultimap<String,
UserPermission> PermissionStorage.getPermissions
(org.apache.hadoop.conf.Configuration conf, byte[] entryName, Table t, byte[] cf, byte[] cq, String user, boolean hasFilterUser) Reads user permission assignments stored in thel:
column family of the first table row in_acl_
.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.getTableUsers
(Table aclTable, TableName tableName) (package private) static List<byte[]>
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.getUserEntries
(Table aclTable, String userName) SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.getUserNamespaceAndTable
(Table aclTable, String userName) private static boolean
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.hasUserEntry
(Table aclTable, String userName, byte[] entry) (package private) static boolean
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.hasUserGlobalHdfsAcl
(Table aclTable, String user) (package private) static boolean
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.hasUserNamespaceHdfsAcl
(Table aclTable, String user, String namespace) (package private) static boolean
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.hasUserTableHdfsAcl
(Table aclTable, String user, TableName tableName) private boolean
SnapshotScannerHDFSAclController.isHdfsAclSet
(Table aclTable, String userName) private boolean
SnapshotScannerHDFSAclController.isHdfsAclSet
(Table aclTable, String userName, String namespace) private boolean
SnapshotScannerHDFSAclController.isHdfsAclSet
(Table aclTable, String userName, String namespace, TableName tableName) Check if user global/namespace/table HDFS acls is already setprivate boolean
SnapshotScannerHDFSAclController.isHdfsAclSet
(Table aclTable, String userName, TableName tableName) (package private) static void
PermissionStorage.removeNamespacePermissions
(org.apache.hadoop.conf.Configuration conf, String namespace, Table t) Remove specified namespace from the acl table.private static void
PermissionStorage.removePermissionRecord
(org.apache.hadoop.conf.Configuration conf, UserPermission userPerm, Table t) (package private) static void
PermissionStorage.removeTablePermissions
(org.apache.hadoop.conf.Configuration conf, TableName tableName, byte[] column, Table t) Remove specified table column from the acl table.(package private) static void
PermissionStorage.removeTablePermissions
(org.apache.hadoop.conf.Configuration conf, TableName tableName, Table t) Remove specified table from the _acl_ table.private static void
PermissionStorage.removeTablePermissions
(TableName tableName, byte[] column, Table table, boolean closeTable) private void
SnapshotScannerHDFSAclController.removeUserGlobalHdfsAcl
(Table aclTable, String userName, UserPermission userPermission) private void
SnapshotScannerHDFSAclController.removeUserNamespaceHdfsAcl
(Table aclTable, String userName, String namespace, UserPermission userPermission) static void
PermissionStorage.removeUserPermission
(org.apache.hadoop.conf.Configuration conf, UserPermission userPerm, Table t) Removes a previously granted permission from the stored access control lists.private void
SnapshotScannerHDFSAclController.removeUserTableHdfsAcl
(Table aclTable, String userName, TableName tableName, UserPermission userPermission) -
Uses of Table in org.apache.hadoop.hbase.thrift
Modifier and TypeMethodDescriptionprotected Table
HBaseServiceHandler.getTable
(byte[] tableName) Creates and returns a Table instance from a given table name.protected Table
HBaseServiceHandler.getTable
(ByteBuffer tableName) Modifier and TypeMethodDescriptionprivate void
ThriftHBaseServiceHandler.closeTable
(Table table) (package private) byte[][]
ThriftHBaseServiceHandler.getAllColumns
(Table table) Returns a list of all the column families for a given Table. -
Uses of Table in org.apache.hadoop.hbase.thrift2
Modifier and TypeMethodDescriptionprotected Table
ThriftHBaseServiceHandler.getTable
(ByteBuffer tableName) -
Uses of Table in org.apache.hadoop.hbase.thrift2.client
-
Uses of Table in org.apache.hadoop.hbase.tool
Modifier and TypeMethodDescriptionprivate Void
CanaryTool.RegionTask.readColumnFamily
(Table table, ColumnFamilyDescriptor column) -
Uses of Table in org.apache.hadoop.hbase.util
Modifier and TypeFieldDescriptionprivate Table
HBaseFsck.meta
Deprecated.protected final Table
MultiThreadedReader.HBaseReaderThread.table
protected final Table
MultiThreadedUpdater.HBaseUpdaterThread.table
private Table
MultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL.MutateAccessAction.table
private final Table
MultiThreadedWriter.HBaseWriterThread.table
private Table
MultiThreadedWriterWithACL.HBaseWriterThreadWithACL.table
Modifier and TypeFieldDescriptionMultiThreadedReaderWithACL.userVsTable
Maps user with Table instance.MultiThreadedUpdaterWithACL.userVsTable
Maps user with Table instance.Modifier and TypeMethodDescriptionprotected Table
MultiThreadedReader.HBaseReaderThread.createTable()
protected Table
MultiThreadedReaderWithACL.HBaseReaderThreadWithACL.createTable()
protected Table
MultiThreadedUpdater.HBaseUpdaterThread.createTable()
protected Table
MultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL.createTable()
protected Table
MultiThreadedWriter.HBaseWriterThread.createTable()
protected Table
MultiThreadedWriterWithACL.HBaseWriterThreadWithACL.createTable()
Caller closes the table afterwards.Modifier and TypeMethodDescriptionprotected String
MultiThreadedWriterBase.getRegionDebugInfoSafe
(Table table, byte[] rowKey) void
void
void
void
MultiThreadedUpdater.HBaseUpdaterThread.mutate
(Table table, Mutation m, long keyBase, byte[] row, byte[] cf, byte[] q, byte[] v) void
void
MultiThreadedUpdater.mutate
(Table table, Mutation m, long keyBase, byte[] row, byte[] cf, byte[] q, byte[] v) void
MultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL.mutate
(Table table, Mutation m, long keyBase, byte[] row, byte[] cf, byte[] q, byte[] v) private void
MultiThreadedWriterWithACL.recordFailure
(Table table, Put put, long keyBase, long start, IOException e) protected void
MultiThreadedReader.HBaseReaderThread.verifyResultsAndUpdateMetrics
(boolean verify, Get[] gets, long elapsedNano, Result[] results, Table table, boolean isNullExpected) protected void
MultiThreadedReader.HBaseReaderThread.verifyResultsAndUpdateMetrics
(boolean verify, Get get, long elapsedNano, Result result, Table table, boolean isNullExpected) private void
MultiThreadedReader.HBaseReaderThread.verifyResultsAndUpdateMetricsOnAPerGetBasis
(boolean verify, Get get, Result result, Table table, boolean isNullExpected) -
Uses of Table in org.apache.hbase.archetypes.exemplars.client
Modifier and TypeMethodDescription(package private) static void
Invokes Table#delete to delete test data (i.e.(package private) static void
HelloHBase.getAndPrintRowContents
(Table table) Invokes Table#get and prints out the contents of the retrieved row.(package private) static void
HelloHBase.putRowToTable
(Table table) Invokes Table#put to store a row (with two new columns created 'on the fly') into the table. -
Uses of Table in org.apache.hbase.archetypes.exemplars.shaded_client
Modifier and TypeMethodDescription(package private) static void
Invokes Table#delete to delete test data (i.e.(package private) static void
HelloHBase.getAndPrintRowContents
(Table table) Invokes Table#get and prints out the contents of the retrieved row.(package private) static void
HelloHBase.putRowToTable
(Table table) Invokes Table#put to store a row (with two new columns created 'on the fly') into the table.