public class DrillHiveMetaStoreClient
extends org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Modifier and Type | Method and Description |
---|---|
List<String> |
getDatabases(boolean ignoreAuthzErrors)
Lists all Hive database names.
|
String |
getDelegationToken(String owner,
String renewerKerberosPrincipalName)
Overridden to enforce synchronization.
|
HiveReadEntry |
getHiveReadEntry(String dbName,
String tableName,
boolean ignoreAuthzErrors)
Returns table metadata for concrete table
|
Map<String,org.apache.calcite.schema.Schema.TableType> |
getTableNamesAndTypes(String dbName,
boolean ignoreAuthzErrors)
Returns collection of view and table names along with their types.
|
abortTxns, add_partition, add_partition, add_partitions_pspec, add_partitions, add_partitions, addCheckConstraint, addDefaultConstraint, addDynamicPartitions, addDynamicPartitions, addForeignKey, addMasterKey, addNotNullConstraint, addPrimaryKey, addRuntimeStat, addSchemaVersion, addSerDe, addToken, addUniqueConstraint, allocateTableWriteId, allocateTableWriteIdsBatch, alter_partition, alter_partition, alter_partition, alter_partitions, alter_partitions, alter_partitions, alter_table_with_environmentContext, alter_table, alter_table, alter_table, alterCatalog, alterDatabase, alterDatabase, alterFunction, alterFunction, alterISchema, alterResourcePlan, alterWMPool, alterWMTrigger, appendPartition, appendPartition, appendPartition, appendPartition, appendPartition, appendPartitionByName, appendPartitionByName, cacheFileMetadata, cancelDelegationToken, checkLock, clearFileMetadata, close, commitTxn, compact, compact, compact2, create_role, create_table_with_environment_context, createCatalog, createDatabase, createFunction, createISchema, createOrDropTriggerToPoolMapping, createOrUpdateWMMapping, createResourcePlan, createTable, createTable, createTableWithConstraints, createType, createWMPool, createWMTrigger, deepCopy, deepCopy, deepCopy, deepCopyFieldSchemas, deletePartitionColumnStatistics, deletePartitionColumnStatistics, deleteTableColumnStatistics, deleteTableColumnStatistics, drop_role, drop_table_with_environment_context, dropCatalog, dropConstraint, dropConstraint, dropDatabase, dropDatabase, dropDatabase, dropDatabase, dropFunction, dropFunction, dropISchema, dropPartition, dropPartition, dropPartition, dropPartition, dropPartition, dropPartition, dropPartition, dropPartition, dropPartition, dropPartitionByName, dropPartitionByName, dropPartitions, dropPartitions, dropPartitions, dropPartitions, dropResourcePlan, dropSchemaVersion, dropTable, dropTable, dropTable, dropTable, dropTable, dropType, dropWMMapping, dropWMPool, dropWMTrigger, exchange_partition, exchange_partition, exchange_partitions, exchange_partitions, fireListenerEvent, flushCache, get_principals_in_role, get_privilege_set, get_role_grants_for_principal, getActiveResourcePlan, getAggrColStatsFor, getAggrColStatsFor, getAllDatabases, getAllDatabases, getAllFunctions, getAllResourcePlans, getAllTables, getAllTables, getAllTokenIdentifiers, getCatalog, getCatalogs, getCheckConstraints, getConfigValue, getCurrentNotificationEventId, getDatabase, getDatabase, getDatabases, getDatabases, getDefaultConstraints, getDelegationToken, getFields, getFields, getFileMetadata, getFileMetadataBySarg, getForeignKeys, getFunction, getFunction, getFunctions, getFunctions, getISchema, getMasterKeys, getMaterializationInvalidationInfo, getMaterializedViewsForRewriting, getMaterializedViewsForRewriting, getMetaConf, getMetastoreDbUuid, getNextNotification, getNotificationEventsCount, getNotNullConstraints, getNumPartitionsByFilter, getNumPartitionsByFilter, getPartition, getPartition, getPartition, getPartition, getPartitionColumnStatistics, getPartitionColumnStatistics, getPartitionsByNames, getPartitionsByNames, getPartitionWithAuthInfo, getPartitionWithAuthInfo, getPrimaryKeys, getResourcePlan, getRuntimeStats, getSchema, getSchema, getSchemaAllVersions, getSchemaByCols, getSchemaLatestVersion, getSchemaVersion, getSerDe, getTable, getTable, getTableColumnStatistics, getTableColumnStatistics, getTableMeta, getTableMeta, getTableObjectsByName, getTableObjectsByName, getTables, getTables, getTables, getTables, getToken, getTokenStrForm, getTriggersForResourcePlan, getTTransport, getType, getTypeAll, getUniqueConstraints, getValidTxns, getValidTxns, getValidWriteIds, getValidWriteIds, grant_privileges, grant_role, heartbeat, heartbeatLockMaterializationRebuild, heartbeatTxnRange, insertTable, isCompatibleWith, isLocalMetaStore, isPartitionMarkedForEvent, isPartitionMarkedForEvent, isSameConfObj, list_privileges, list_roles, listPartitionNames, listPartitionNames, listPartitionNames, listPartitionNames, listPartitions, listPartitions, listPartitions, listPartitions, listPartitionsByExpr, listPartitionsByExpr, listPartitionsByFilter, listPartitionsByFilter, listPartitionSpecs, listPartitionSpecs, listPartitionSpecsByFilter, listPartitionSpecsByFilter, listPartitionsWithAuthInfo, listPartitionsWithAuthInfo, listPartitionsWithAuthInfo, listPartitionsWithAuthInfo, listPartitionValues, listRoleNames, listTableNamesByFilter, listTableNamesByFilter, lock, lockMaterializationRebuild, mapSchemaVersionToSerde, markPartitionForEvent, markPartitionForEvent, newSynchronizedClient, openTxn, openTxns, partitionNameToSpec, partitionNameToVals, putFileMetadata, reconnect, recycleDirToCmPath, refresh_privileges, removeMasterKey, removeToken, renamePartition, renamePartition, renewDelegationToken, replAllocateTableWriteIdsBatch, replCommitTxn, replOpenTxn, replRollbackTxn, replTableWriteIdState, revoke_privileges, revoke_role, rollbackTxn, setHiveAddedJars, setMetaConf, setPartitionColumnStatistics, setSchemaVersionState, showCompactions, showLocks, showLocks, showTxns, tableExists, tableExists, truncateTable, truncateTable, unlock, updateCreationMetadata, updateCreationMetadata, updateMasterKey, updatePartitionColumnStatistics, updateTableColumnStatistics, validatePartitionNameCharacters, validateResourcePlan
public List<String> getDatabases(boolean ignoreAuthzErrors) throws org.apache.thrift.TException
ignoreAuthzErrors
- whether authorization errors should be ignoredorg.apache.thrift.TException
- when client failspublic HiveReadEntry getHiveReadEntry(String dbName, String tableName, boolean ignoreAuthzErrors) throws org.apache.thrift.TException
dbName
- name of databasetableName
- name of tableHiveReadEntry
containing table meta like columns, partitions etc.org.apache.thrift.TException
- when client failspublic Map<String,org.apache.calcite.schema.Schema.TableType> getTableNamesAndTypes(String dbName, boolean ignoreAuthzErrors) throws org.apache.thrift.TException
dbName
- name of databaseignoreAuthzErrors
- hint for handling authorization errorsorg.apache.thrift.TException
- in case when if loader thrown ExecutionExceptionpublic String getDelegationToken(String owner, String renewerKerberosPrincipalName) throws org.apache.thrift.TException
getDelegationToken
in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
getDelegationToken
in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
owner
- the intended owner for the tokenrenewerKerberosPrincipalName
- kerberos userorg.apache.thrift.TException
- when client failsCopyright © 1970 The Apache Software Foundation. All rights reserved.