Uses of Interface
org.apache.hadoop.hbase.client.Table
Packages that use 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.
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
Methods in org.apache.hadoop.hbase that return TableModifier and TypeMethodDescriptionstatic Table
MetaTableAccessor.getMetaHTable
(Connection connection) Callers should call close on the returnedTable
instance.Methods in org.apache.hadoop.hbase with parameters of type TableModifier and TypeMethodDescriptionprivate static Result
(package private) static void
MetaTableAccessor.multiMutate
(Table table, byte[] row, List<Mutation> mutations) Performs an atomic multi-mutate operation against the given table.private static void
MetaTableAccessor.multiMutate
(Table table, byte[] row, Mutation... mutations) private static void
-
Uses of Table in org.apache.hadoop.hbase.client
Classes in org.apache.hadoop.hbase.client that implement TableFields in org.apache.hadoop.hbase.client declared as TableMethods in org.apache.hadoop.hbase.client that return TableModifier and TypeMethodDescriptionTableBuilder.build()
Create theTable
instance.default Table
Retrieve a Table implementation for accessing a table.default Table
Connection.getTable
(TableName tableName, ExecutorService pool) Retrieve a Table implementation for accessing a table.Constructors in org.apache.hadoop.hbase.client with parameters of type TableModifierConstructorDescriptionSecureBulkLoadClient
(org.apache.hadoop.conf.Configuration conf, Table table) -
Uses of Table in org.apache.hadoop.hbase.client.example
Methods in org.apache.hadoop.hbase.client.example with parameters of type Table -
Uses of Table in org.apache.hadoop.hbase.mapred
Fields in org.apache.hadoop.hbase.mapred declared as TableModifier and TypeFieldDescriptionprivate Table
TableRecordReaderImpl.htable
private Table
TableInputFormatBase.table
Methods in org.apache.hadoop.hbase.mapred that return TableModifier and TypeMethodDescriptionprotected Table
TableInputFormatBase.getTable()
Allows subclasses to get theTable
.Methods in org.apache.hadoop.hbase.mapred with parameters of type Table -
Uses of Table in org.apache.hadoop.hbase.mapreduce
Fields in org.apache.hadoop.hbase.mapreduce declared as TableModifier and TypeFieldDescriptionprivate Table
TableRecordReaderImpl.htable
(package private) Table
SyncTable.SyncMapper.sourceTable
private Table
TableInputFormatBase.table
TheTable
to scan.(package private) Table
SyncTable.SyncMapper.targetTable
Methods in org.apache.hadoop.hbase.mapreduce that return TableModifier 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) Methods in org.apache.hadoop.hbase.mapreduce with parameters of type TableModifier 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
Fields in org.apache.hadoop.hbase.mapreduce.replication declared as TableModifier and TypeFieldDescriptionprivate Table
VerifyReplication.Verifier.replicatedTable
private final Table
VerifyReplicationRecompareRunnable.replicatedTable
private Table
VerifyReplication.Verifier.sourceTable
private final Table
VerifyReplicationRecompareRunnable.sourceTable
Constructors in org.apache.hadoop.hbase.mapreduce.replication with parameters of type TableModifierConstructorDescriptionVerifyReplicationRecompareRunnable
(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
Fields in org.apache.hadoop.hbase.master declared as TableMethods in org.apache.hadoop.hbase.master that return TableMethods in org.apache.hadoop.hbase.master with parameters of type Table -
Uses of Table in org.apache.hadoop.hbase.master.assignment
Methods in org.apache.hadoop.hbase.master.assignment that return Table -
Uses of Table in org.apache.hadoop.hbase.quotas
Fields in org.apache.hadoop.hbase.quotas declared as TableMethods in org.apache.hadoop.hbase.quotas with parameters of type TableModifier 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.regionserver
Methods in org.apache.hadoop.hbase.replication.regionserver with parameters of type TableModifier and TypeMethodDescriptionprivate void
private void
HFileReplicator.doBulkLoad
(LoadIncrementalHFiles loadHFiles, Table table, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, RegionLocator locator, int maxRetries) -
Uses of Table in org.apache.hadoop.hbase.rest
Methods in org.apache.hadoop.hbase.rest that return Table -
Uses of Table in org.apache.hadoop.hbase.security.access
Methods in org.apache.hadoop.hbase.security.access with parameters of type TableModifier 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
Methods in org.apache.hadoop.hbase.thrift that return TableModifier and TypeMethodDescriptionprotected Table
HBaseServiceHandler.getTable
(byte[] tableName) Creates and returns a Table instance from a given table name.protected Table
HBaseServiceHandler.getTable
(ByteBuffer tableName) Methods in org.apache.hadoop.hbase.thrift with parameters of type TableModifier 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
Methods in org.apache.hadoop.hbase.thrift2 that return TableModifier and TypeMethodDescriptionprotected Table
ThriftHBaseServiceHandler.getTable
(ByteBuffer tableName) Methods in org.apache.hadoop.hbase.thrift2 with parameters of type Table -
Uses of Table in org.apache.hadoop.hbase.thrift2.client
Classes in org.apache.hadoop.hbase.thrift2.client that implement Table -
Uses of Table in org.apache.hadoop.hbase.tool
Methods in org.apache.hadoop.hbase.tool with parameters of type TableModifier and TypeMethodDescriptionprotected void
LoadIncrementalHFiles.bulkLoadPhase
(Table table, Connection conn, ExecutorService pool, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer, LoadIncrementalHFiles.LoadQueueItem> regionGroups, boolean copyFile, Map<LoadIncrementalHFiles.LoadQueueItem, ByteBuffer> item2RegionMap) Deprecated.This takes the LQI's grouped by likely regions and attempts to bulk load them.LoadIncrementalHFiles.doBulkLoad
(Map<byte[], List<org.apache.hadoop.fs.Path>> map, Admin admin, Table table, RegionLocator regionLocator, boolean silence, boolean copyFile) Deprecated.Perform a bulk load of the given directory into the given pre-existing table.LoadIncrementalHFiles.doBulkLoad
(org.apache.hadoop.fs.Path hfofDir, Admin admin, Table table, RegionLocator regionLocator) Deprecated.Perform a bulk load of the given directory into the given pre-existing table.LoadIncrementalHFiles.doBulkLoad
(org.apache.hadoop.fs.Path hfofDir, Admin admin, Table table, RegionLocator regionLocator, boolean silence, boolean copyFile) Deprecated.Perform a bulk load of the given directory into the given pre-existing table.protected Pair<List<LoadIncrementalHFiles.LoadQueueItem>,
String> LoadIncrementalHFiles.groupOrSplit
(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer, LoadIncrementalHFiles.LoadQueueItem> regionGroups, LoadIncrementalHFiles.LoadQueueItem item, Table table, Pair<byte[][], byte[][]> startEndKeys) Deprecated.Attempt to assign the given load queue item into its target region group.private Pair<org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer,
LoadIncrementalHFiles.LoadQueueItem>, Set<String>> LoadIncrementalHFiles.groupOrSplitPhase
(Table table, ExecutorService pool, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, Pair<byte[][], byte[][]> startEndKeys) Deprecated.void
LoadIncrementalHFiles.loadHFileQueue
(Table table, Connection conn, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, Pair<byte[][], byte[][]> startEndKeys) Deprecated.Used by the replication sink to load the hfiles from the source cluster.void
LoadIncrementalHFiles.loadHFileQueue
(Table table, Connection conn, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, Pair<byte[][], byte[][]> startEndKeys, boolean copyFile) Deprecated.Used by the replication sink to load the hfiles from the source cluster.LoadIncrementalHFiles.performBulkLoad
(Admin admin, Table table, RegionLocator regionLocator, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, ExecutorService pool, SecureBulkLoadClient secureClient, boolean copyFile) Deprecated.void
LoadIncrementalHFiles.prepareHFileQueue
(Map<byte[], List<org.apache.hadoop.fs.Path>> map, Table table, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, boolean silence) Deprecated.Prepare a collection ofLoadIncrementalHFiles.LoadQueueItem
from list of source hfiles contained in the passed directory and validates whether the prepared queue has all the valid table column families in it.void
LoadIncrementalHFiles.prepareHFileQueue
(org.apache.hadoop.fs.Path hfilesDir, Table table, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, boolean validateHFile) Deprecated.Prepare a collection ofLoadIncrementalHFiles.LoadQueueItem
from list of source hfiles contained in the passed directory and validates whether the prepared queue has all the valid table column families in it.void
LoadIncrementalHFiles.prepareHFileQueue
(org.apache.hadoop.fs.Path hfilesDir, Table table, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, boolean validateHFile, boolean silence) Deprecated.Prepare a collection ofLoadIncrementalHFiles.LoadQueueItem
from list of source hfiles contained in the passed directory and validates whether the prepared queue has all the valid table column families in it.private Void
CanaryTool.RegionTask.readColumnFamily
(Table table, ColumnFamilyDescriptor column) private List<LoadIncrementalHFiles.LoadQueueItem>
LoadIncrementalHFiles.splitStoreFile
(LoadIncrementalHFiles.LoadQueueItem item, Table table, byte[] startKey, byte[] splitKey) Deprecated.private void
LoadIncrementalHFiles.validateFamiliesInHFiles
(Table table, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, boolean silence) Deprecated.Checks whether there is any invalid family name in HFiles to be bulk loaded. -
Uses of Table in org.apache.hadoop.hbase.util
Fields in org.apache.hadoop.hbase.util declared as TableMethods in org.apache.hadoop.hbase.util that return Table -
Uses of Table in org.apache.hbase.archetypes.exemplars.client
Methods in org.apache.hbase.archetypes.exemplars.client with parameters of type TableModifier 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
Methods in org.apache.hbase.archetypes.exemplars.shaded_client with parameters of type TableModifier 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.