Modifier and Type | Method and Description |
---|---|
static Table |
MetaTableAccessor.getMetaHTable(Connection connection)
Callers should call close on the returned
Table instance. |
Modifier and Type | Method and Description |
---|---|
private static Result |
MetaTableAccessor.get(Table t,
Get g) |
(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 |
MetaTableAccessor.put(Table t,
Put p) |
Modifier and Type | Class and Description |
---|---|
class |
HTable
An implementation of
Table . |
Modifier and Type | Field and Description |
---|---|
private Table |
SecureBulkLoadClient.table |
Modifier and Type | Method and Description |
---|---|
Table |
TableBuilder.build()
Create the
Table instance. |
Table |
ConnectionImplementation.getTable(TableName tableName) |
default Table |
Connection.getTable(TableName tableName)
Retrieve a Table implementation for accessing a table.
|
default Table |
Connection.getTable(TableName tableName,
ExecutorService pool)
Retrieve a Table implementation for accessing a table.
|
Constructor and Description |
---|
SecureBulkLoadClient(org.apache.hadoop.conf.Configuration conf,
Table table) |
Modifier and Type | Method and Description |
---|---|
void |
RefreshHFilesClient.refreshHFiles(Table table) |
Modifier and Type | Field and Description |
---|---|
private Table |
TableRecordReaderImpl.htable |
private Table |
TableInputFormatBase.table |
Modifier and Type | Method and Description |
---|---|
protected Table |
TableInputFormatBase.getTable()
Allows subclasses to get the
Table . |
Modifier and Type | Method and Description |
---|---|
void |
TableRecordReader.setHTable(Table htable) |
void |
TableRecordReaderImpl.setHTable(Table htable) |
Modifier and Type | Field and Description |
---|---|
private Table |
TableRecordReaderImpl.htable |
(package private) Table |
SyncTable.SyncMapper.sourceTable |
private Table |
TableInputFormatBase.table
The
Table to scan. |
(package private) Table |
SyncTable.SyncMapper.targetTable |
Modifier and Type | Method and Description |
---|---|
protected Table |
TableInputFormatBase.getTable()
Allows subclasses to get the
Table . |
private static Table |
SyncTable.SyncMapper.openTable(Connection connection,
org.apache.hadoop.conf.Configuration conf,
String tableNameConfKey) |
Modifier and Type | Method and Description |
---|---|
static 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 |
TableRecordReaderImpl.setHTable(Table htable)
Sets the HBase table.
|
void |
TableRecordReader.setTable(Table table) |
Modifier and Type | Field and Description |
---|---|
private Table |
VerifyReplication.Verifier.replicatedTable |
private Table |
VerifyReplication.Verifier.sourceTable |
Modifier and Type | Field and Description |
---|---|
private Table |
TableNamespaceManager.nsTable |
Modifier and Type | Method and Description |
---|---|
private Table |
TableNamespaceManager.getNamespaceTable() |
Modifier and Type | Method and Description |
---|---|
private NamespaceDescriptor |
TableNamespaceManager.get(Table table,
String name) |
Modifier and Type | Method and Description |
---|---|
private Table |
RegionStateStore.getMetaTable() |
Modifier and Type | Field and Description |
---|---|
private Table |
QuotaRetriever.table |
Modifier and Type | Method and Description |
---|---|
(package private) long |
FileArchiverNotifierImpl.getPreviousNamespaceSnapshotSize(Table quotaTable,
String namespace)
Fetches the current size of all snapshots in the given
namespace . |
(package private) void |
FileArchiverNotifierImpl.persistSnapshotSizes(Table table,
List<FileArchiverNotifierImpl.SnapshotWithSize> snapshotSizes)
Writes the snapshot sizes to the provided
table . |
Modifier and Type | Method and Description |
---|---|
private void |
HFileReplicator.cleanup(String stagingDir,
Table table) |
private void |
HFileReplicator.doBulkLoad(LoadIncrementalHFiles loadHFiles,
Table table,
Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
RegionLocator locator,
int maxRetries) |
Modifier and Type | Method and Description |
---|---|
(package private) Table |
RESTServlet.getTable(String tableName)
Caller closes the table afterwards.
|
Modifier and Type | Method and Description |
---|---|
private 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) |
private Set<String> |
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.
|
private static Set<String> |
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 the
l: column family of the first
table row in _acl_ . |
(package private) static Set<String> |
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.getTableUsers(Table aclTable,
TableName tableName) |
(package private) static List<byte[]> |
SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage.getUserEntries(Table aclTable,
String userName) |
(package private) static Pair<Set<String>,Set<TableName>> |
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 set
|
private 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) |
Modifier and Type | Method and Description |
---|---|
protected Table |
HBaseServiceHandler.getTable(byte[] tableName)
Creates and returns a Table instance from a given table name.
|
protected Table |
HBaseServiceHandler.getTable(ByteBuffer tableName) |
Modifier and Type | Method and Description |
---|---|
private void |
ThriftHBaseServiceHandler.closeTable(Table table) |
(package private) byte[][] |
ThriftHBaseServiceHandler.getAllColumns(Table table)
Returns a list of all the column families for a given Table.
|
Modifier and Type | Method and Description |
---|---|
protected Table |
ThriftHBaseServiceHandler.getTable(ByteBuffer tableName) |
Modifier and Type | Method and Description |
---|---|
private void |
ThriftHBaseServiceHandler.closeTable(Table table) |
Modifier and Type | Class and Description |
---|---|
class |
ThriftTable |
Modifier and Type | Method and Description |
---|---|
protected 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.
|
Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> |
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.
|
Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> |
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.
|
Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> |
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.
|
private Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> |
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 of
LoadIncrementalHFiles.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 of
LoadIncrementalHFiles.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 of
LoadIncrementalHFiles.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.
|
Modifier and Type | Field and Description |
---|---|
private Table |
HBaseFsck.meta
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
Table |
ConnectionCache.getTable(String tableName)
Caller closes the table afterwards.
|
Modifier and Type | Method and Description |
---|---|
(package private) static void |
HelloHBase.deleteRow(Table table)
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.
|
Modifier and Type | Method and Description |
---|---|
(package private) static void |
HelloHBase.deleteRow(Table table)
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.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.