public interface RawStore
extends org.apache.hadoop.conf.Configurable
| Modifier and Type | Interface and Description |
|---|---|
static interface |
RawStore.CanNotRetry
Annotation to skip retries
|
| Modifier and Type | Method and Description |
|---|---|
List<String> |
addCheckConstraints(List<org.apache.hadoop.hive.metastore.api.SQLCheckConstraint> cc)
Add check constraints to a table
|
List<String> |
addDefaultConstraints(List<org.apache.hadoop.hive.metastore.api.SQLDefaultConstraint> dv)
Add default values to a table definition
|
List<String> |
addForeignKeys(List<org.apache.hadoop.hive.metastore.api.SQLForeignKey> fks)
Add a foreign key to a table.
|
int |
addMasterKey(String key) |
void |
addNotificationEvent(org.apache.hadoop.hive.metastore.api.NotificationEvent event)
Add a notification entry.
|
List<String> |
addNotNullConstraints(List<org.apache.hadoop.hive.metastore.api.SQLNotNullConstraint> nns)
Add not null constraints to a table.
|
boolean |
addPartition(org.apache.hadoop.hive.metastore.api.Partition part)
Add a partition.
|
boolean |
addPartitions(String catName,
String dbName,
String tblName,
List<org.apache.hadoop.hive.metastore.api.Partition> parts)
Add a list of partitions to a table.
|
boolean |
addPartitions(String catName,
String dbName,
String tblName,
PartitionSpecProxy partitionSpec,
boolean ifNotExists)
Add a list of partitions to a table.
|
List<String> |
addPrimaryKeys(List<org.apache.hadoop.hive.metastore.api.SQLPrimaryKey> pks)
Add a primary key to a table.
|
boolean |
addRole(String rowName,
String ownerName) |
void |
addRuntimeStat(org.apache.hadoop.hive.metastore.api.RuntimeStat stat)
Adds a RuntimeStat for persistence.
|
void |
addSchemaVersion(org.apache.hadoop.hive.metastore.api.SchemaVersion schemaVersion)
Create a new version of an existing schema.
|
void |
addSerde(org.apache.hadoop.hive.metastore.api.SerDeInfo serde)
Add a serde
|
boolean |
addToken(String tokenIdentifier,
String delegationToken) |
List<String> |
addUniqueConstraints(List<org.apache.hadoop.hive.metastore.api.SQLUniqueConstraint> uks)
Add unique constraints to a table.
|
void |
alterCatalog(String catName,
org.apache.hadoop.hive.metastore.api.Catalog cat)
Alter an existing catalog.
|
boolean |
alterDatabase(String catalogName,
String dbname,
org.apache.hadoop.hive.metastore.api.Database db)
Alter a database.
|
void |
alterFunction(String catName,
String dbName,
String funcName,
org.apache.hadoop.hive.metastore.api.Function newFunction)
Alter function based on new function specs.
|
void |
alterISchema(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName,
org.apache.hadoop.hive.metastore.api.ISchema newSchema)
Alter an existing ISchema.
|
void |
alterPartition(String catName,
String db_name,
String tbl_name,
List<String> part_vals,
org.apache.hadoop.hive.metastore.api.Partition new_part)
Alter a partition.
|
void |
alterPartitions(String catName,
String db_name,
String tbl_name,
List<List<String>> part_vals_list,
List<org.apache.hadoop.hive.metastore.api.Partition> new_parts)
Alter a set of partitions.
|
void |
alterPool(org.apache.hadoop.hive.metastore.api.WMNullablePool pool,
String poolPath) |
org.apache.hadoop.hive.metastore.api.WMFullResourcePlan |
alterResourcePlan(String name,
org.apache.hadoop.hive.metastore.api.WMNullableResourcePlan resourcePlan,
boolean canActivateDisabled,
boolean canDeactivate,
boolean isReplace) |
void |
alterSchemaVersion(org.apache.hadoop.hive.metastore.api.SchemaVersionDescriptor version,
org.apache.hadoop.hive.metastore.api.SchemaVersion newVersion)
Alter a schema version.
|
void |
alterTable(String catName,
String dbname,
String name,
org.apache.hadoop.hive.metastore.api.Table newTable)
Alter a table.
|
void |
alterWMTrigger(org.apache.hadoop.hive.metastore.api.WMTrigger trigger) |
void |
cleanNotificationEvents(int olderThan)
Remove older notification events.
|
long |
cleanupEvents() |
boolean |
commitTransaction()
if this is the commit of the first open call then an actual commit is
called.
|
void |
createCatalog(org.apache.hadoop.hive.metastore.api.Catalog cat)
Create a new catalog.
|
void |
createDatabase(org.apache.hadoop.hive.metastore.api.Database db)
Create a database.
|
void |
createFunction(org.apache.hadoop.hive.metastore.api.Function func)
Register a user-defined function based on the function specification passed in.
|
void |
createISchema(org.apache.hadoop.hive.metastore.api.ISchema schema)
Create a new ISchema.
|
void |
createOrUpdateWMMapping(org.apache.hadoop.hive.metastore.api.WMMapping mapping,
boolean update) |
void |
createPool(org.apache.hadoop.hive.metastore.api.WMPool pool) |
void |
createResourcePlan(org.apache.hadoop.hive.metastore.api.WMResourcePlan resourcePlan,
String copyFrom,
int defaultPoolSize) |
void |
createTable(org.apache.hadoop.hive.metastore.api.Table tbl) |
List<String> |
createTableWithConstraints(org.apache.hadoop.hive.metastore.api.Table tbl,
List<org.apache.hadoop.hive.metastore.api.SQLPrimaryKey> primaryKeys,
List<org.apache.hadoop.hive.metastore.api.SQLForeignKey> foreignKeys,
List<org.apache.hadoop.hive.metastore.api.SQLUniqueConstraint> uniqueConstraints,
List<org.apache.hadoop.hive.metastore.api.SQLNotNullConstraint> notNullConstraints,
List<org.apache.hadoop.hive.metastore.api.SQLDefaultConstraint> defaultConstraints,
List<org.apache.hadoop.hive.metastore.api.SQLCheckConstraint> checkConstraints)
Create a table with constraints
|
boolean |
createType(org.apache.hadoop.hive.metastore.api.Type type) |
void |
createWMTrigger(org.apache.hadoop.hive.metastore.api.WMTrigger trigger) |
void |
createWMTriggerToPoolMapping(String resourcePlanName,
String triggerName,
String poolPath) |
boolean |
deletePartitionColumnStatistics(String catName,
String dbName,
String tableName,
String partName,
List<String> partVals,
String colName)
Deletes column statistics if present associated with a given db, table, partition and col.
|
int |
deleteRuntimeStats(int maxRetainSecs)
Removes outdated statistics.
|
boolean |
deleteTableColumnStatistics(String catName,
String dbName,
String tableName,
String colName)
Delete statistics for a single column or all columns in a table.
|
boolean |
doesPartitionExist(String catName,
String dbName,
String tableName,
List<String> part_vals)
Check whether a partition exists.
|
void |
dropCatalog(String catalogName)
Drop a catalog.
|
default void |
dropConstraint(String catName,
String dbName,
String tableName,
String constraintName)
Drop a constraint, any constraint.
|
void |
dropConstraint(String catName,
String dbName,
String tableName,
String constraintName,
boolean missingOk)
Drop a constraint, any constraint.
|
boolean |
dropDatabase(String catalogName,
String dbname)
Drop a database.
|
void |
dropFunction(String catName,
String dbName,
String funcName)
Drop a function definition.
|
void |
dropISchema(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName)
Drop an ISchema.
|
boolean |
dropPartition(String catName,
String dbName,
String tableName,
List<String> part_vals)
Drop a partition.
|
void |
dropPartitions(String catName,
String dbName,
String tblName,
List<String> partNames)
Drop a list of partitions.
|
void |
dropResourcePlan(String name) |
void |
dropSchemaVersion(org.apache.hadoop.hive.metastore.api.SchemaVersionDescriptor version)
Drop a version of the schema.
|
boolean |
dropTable(String catalogName,
String dbName,
String tableName)
Drop a table.
|
boolean |
dropType(String typeName) |
void |
dropWMMapping(org.apache.hadoop.hive.metastore.api.WMMapping mapping) |
void |
dropWMPool(String resourcePlanName,
String poolPath) |
void |
dropWMTrigger(String resourcePlanName,
String triggerName) |
void |
dropWMTriggerToPoolMapping(String resourcePlanName,
String triggerName,
String poolPath) |
void |
flushCache() |
org.apache.hadoop.hive.metastore.api.AggrStats |
get_aggr_stats_for(String catName,
String dbName,
String tblName,
List<String> partNames,
List<String> colNames)
Get aggregated stats for a table or partition(s).
|
org.apache.hadoop.hive.metastore.api.WMFullResourcePlan |
getActiveResourcePlan() |
List<String> |
getAllDatabases(String catalogName)
Get names of all the databases in a catalog.
|
List<org.apache.hadoop.hive.metastore.api.Function> |
getAllFunctions(String catName)
Retrieve all functions.
|
List<org.apache.hadoop.hive.metastore.api.WMResourcePlan> |
getAllResourcePlans() |
List<org.apache.hadoop.hive.metastore.api.SchemaVersion> |
getAllSchemaVersion(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName)
Get all of the versions of a schema
|
List<MetaStoreUtils.FullTableName> |
getAllTableNamesForStats() |
List<String> |
getAllTables(String catName,
String dbName)
Get all tables in a database.
|
List<String> |
getAllTokenIdentifiers() |
org.apache.hadoop.hive.metastore.api.Catalog |
getCatalog(String catalogName)
Get a catalog.
|
List<String> |
getCatalogs()
Get all the catalogs.
|
List<org.apache.hadoop.hive.metastore.api.SQLCheckConstraint> |
getCheckConstraints(String catName,
String db_name,
String tbl_name)
Get check constraints for columns in a table.
|
org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet |
getColumnPrivilegeSet(String catName,
String dbName,
String tableName,
String partitionName,
String columnName,
String userName,
List<String> groupNames)
Get privileges for a column in a table or partition for a user.
|
org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId |
getCurrentNotificationEventId()
Get the last issued notification event id.
|
org.apache.hadoop.hive.metastore.api.Database |
getDatabase(String catalogName,
String name)
Get a database.
|
int |
getDatabaseCount()
Gets total number of databases.
|
List<String> |
getDatabases(String catalogName,
String pattern)
Get all database in a catalog having names that match a pattern.
|
org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet |
getDBPrivilegeSet(String catName,
String dbName,
String userName,
List<String> groupNames)
Get privileges for a database for a user.
|
List<org.apache.hadoop.hive.metastore.api.SQLDefaultConstraint> |
getDefaultConstraints(String catName,
String db_name,
String tbl_name)
Get default values for columns in a table.
|
ByteBuffer[] |
getFileMetadata(List<Long> fileIds) |
void |
getFileMetadataByExpr(List<Long> fileIds,
org.apache.hadoop.hive.metastore.api.FileMetadataExprType type,
byte[] expr,
ByteBuffer[] metadatas,
ByteBuffer[] exprResults,
boolean[] eliminated)
Gets file metadata from cache after applying a format-specific expression that can
produce additional information based on file metadata and also filter the file list.
|
FileMetadataHandler |
getFileMetadataHandler(org.apache.hadoop.hive.metastore.api.FileMetadataExprType type)
Gets file metadata handler for the corresponding type.
|
List<org.apache.hadoop.hive.metastore.api.SQLForeignKey> |
getForeignKeys(String catName,
String parent_db_name,
String parent_tbl_name,
String foreign_db_name,
String foreign_tbl_name)
Get the foreign keys for a table.
|
org.apache.hadoop.hive.metastore.api.Function |
getFunction(String catName,
String dbName,
String funcName)
Retrieve function by name.
|
List<String> |
getFunctions(String catName,
String dbName,
String pattern)
Retrieve list of function names based on name pattern.
|
org.apache.hadoop.hive.metastore.api.ISchema |
getISchema(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName)
Get an ISchema by name.
|
org.apache.hadoop.hive.metastore.api.SchemaVersion |
getLatestSchemaVersion(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName)
Get the latest version of a schema.
|
String[] |
getMasterKeys() |
List<String> |
getMaterializedViewsForRewriting(String catName,
String dbName)
Get list of materialized views in a database.
|
String |
getMetastoreDbUuid()
Gets the unique id of the backing datastore for the metadata
|
String |
getMetaStoreSchemaVersion() |
org.apache.hadoop.hive.metastore.api.NotificationEventResponse |
getNextNotification(org.apache.hadoop.hive.metastore.api.NotificationEventRequest rqst)
Get the next notification event.
|
org.apache.hadoop.hive.metastore.api.NotificationEventsCountResponse |
getNotificationEventsCount(org.apache.hadoop.hive.metastore.api.NotificationEventsCountRequest rqst)
Get the number of events corresponding to given database with fromEventId.
|
List<org.apache.hadoop.hive.metastore.api.SQLNotNullConstraint> |
getNotNullConstraints(String catName,
String db_name,
String tbl_name)
Get not null constraints on a table.
|
int |
getNumPartitionsByExpr(String catName,
String dbName,
String tblName,
byte[] expr)
Get the number of partitions that match an already parsed expression.
|
int |
getNumPartitionsByFilter(String catName,
String dbName,
String tblName,
String filter)
Get the number of partitions that match a provided SQL filter.
|
org.apache.hadoop.hive.metastore.api.Partition |
getPartition(String catName,
String dbName,
String tableName,
List<String> part_vals)
Get a partition.
|
List<MetaStoreUtils.ColStatsObjWithSourceInfo> |
getPartitionColStatsForDatabase(String catName,
String dbName)
Get column stats for all partitions of all tables in the database
|
Map<String,List<String>> |
getPartitionColsWithStats(String catName,
String dbName,
String tableName) |
List<org.apache.hadoop.hive.metastore.api.ColumnStatistics> |
getPartitionColumnStatistics(String catName,
String dbName,
String tblName,
List<String> partNames,
List<String> colNames)
Get statistics for a partition for a set of columns.
|
int |
getPartitionCount()
Gets total number of partitions.
|
org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet |
getPartitionPrivilegeSet(String catName,
String dbName,
String tableName,
String partition,
String userName,
List<String> groupNames)
Get privileges for a partition for a user.
|
List<org.apache.hadoop.hive.metastore.api.Partition> |
getPartitions(String catName,
String dbName,
String tableName,
int max)
Get some or all partitions for a table.
|
boolean |
getPartitionsByExpr(String catName,
String dbName,
String tblName,
byte[] expr,
String defaultPartitionName,
short maxParts,
List<org.apache.hadoop.hive.metastore.api.Partition> result)
Get partitions using an already parsed expression.
|
List<org.apache.hadoop.hive.metastore.api.Partition> |
getPartitionsByFilter(String catName,
String dbName,
String tblName,
String filter,
short maxParts)
Get partitions with a filter.
|
List<org.apache.hadoop.hive.metastore.api.Partition> |
getPartitionsByNames(String catName,
String dbName,
String tblName,
List<String> partNames)
Get partitions by name.
|
List<org.apache.hadoop.hive.metastore.api.Partition> |
getPartitionsWithAuth(String catName,
String dbName,
String tblName,
short maxParts,
String userName,
List<String> groupNames)
Fetch some or all partitions for a table, along with privilege information for a particular
user.
|
org.apache.hadoop.hive.metastore.api.Partition |
getPartitionWithAuth(String catName,
String dbName,
String tblName,
List<String> partVals,
String user_name,
List<String> group_names)
Fetch a partition along with privilege information for a particular user.
|
List<org.apache.hadoop.hive.metastore.api.SQLPrimaryKey> |
getPrimaryKeys(String catName,
String db_name,
String tbl_name)
Get the primary associated with a table.
|
org.apache.hadoop.hive.metastore.api.WMFullResourcePlan |
getResourcePlan(String name) |
org.apache.hadoop.hive.metastore.api.Role |
getRole(String roleName) |
List<org.apache.hadoop.hive.metastore.api.RuntimeStat> |
getRuntimeStats(int maxEntries,
int maxCreateTime)
Reads runtime statistic entries.
|
org.apache.hadoop.hive.metastore.api.SchemaVersion |
getSchemaVersion(org.apache.hadoop.hive.metastore.api.SchemaVersionDescriptor version)
Get a specific schema version.
|
List<org.apache.hadoop.hive.metastore.api.SchemaVersion> |
getSchemaVersionsByColumns(String colName,
String colNamespace,
String type)
Find all SchemaVersion objects that match a query.
|
org.apache.hadoop.hive.metastore.api.SerDeInfo |
getSerDeInfo(String serDeName)
Get serde information
|
org.apache.hadoop.hive.metastore.api.Table |
getTable(String catalogName,
String dbName,
String tableName)
Get a table object.
|
org.apache.hadoop.hive.metastore.api.ColumnStatistics |
getTableColumnStatistics(String catName,
String dbName,
String tableName,
List<String> colName)
Returns the relevant column statistics for a given column in a given table in a given database
if such statistics exist.
|
int |
getTableCount()
Gets total number of tables.
|
List<org.apache.hadoop.hive.metastore.api.TableMeta> |
getTableMeta(String catName,
String dbNames,
String tableNames,
List<String> tableTypes) |
List<MetaStoreUtils.FullTableName> |
getTableNamesWithStats() |
List<org.apache.hadoop.hive.metastore.api.Table> |
getTableObjectsByName(String catName,
String dbname,
List<String> tableNames) |
org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet |
getTablePrivilegeSet(String catName,
String dbName,
String tableName,
String userName,
List<String> groupNames)
Get privileges for a table for a user.
|
List<String> |
getTables(String catName,
String dbName,
String pattern)
Get table names that match a pattern.
|
List<String> |
getTables(String catName,
String dbName,
String pattern,
TableType tableType)
Get table names that match a pattern.
|
String |
getToken(String tokenIdentifier) |
List<org.apache.hadoop.hive.metastore.api.WMTrigger> |
getTriggersForResourcePlan(String resourcePlanName) |
org.apache.hadoop.hive.metastore.api.Type |
getType(String typeName) |
List<org.apache.hadoop.hive.metastore.api.SQLUniqueConstraint> |
getUniqueConstraints(String catName,
String db_name,
String tbl_name)
Get unique constraints associated with a table.
|
org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet |
getUserPrivilegeSet(String userName,
List<String> groupNames) |
boolean |
grantPrivileges(org.apache.hadoop.hive.metastore.api.PrivilegeBag privileges) |
boolean |
grantRole(org.apache.hadoop.hive.metastore.api.Role role,
String userName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType,
String grantor,
org.apache.hadoop.hive.metastore.api.PrincipalType grantorType,
boolean grantOption) |
boolean |
isActiveTransaction() |
boolean |
isFileMetadataSupported() |
boolean |
isPartitionMarkedForEvent(String catName,
String dbName,
String tblName,
Map<String,String> partName,
org.apache.hadoop.hive.metastore.api.PartitionEventType evtType) |
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listAllTableGrants(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType,
String catName,
String dbName,
String tableName)
For a given principal name and type, list the Table Grants
|
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listDBGrantsAll(String catName,
String dbName)
Find all the privileges for a given database.
|
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listGlobalGrantsAll() |
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listPartitionColumnGrantsAll(String catName,
String dbName,
String tableName,
String partitionName,
String columnName)
Find all of the privileges for a given column in a given partition.
|
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listPartitionGrantsAll(String catName,
String dbName,
String tableName,
String partitionName)
Find all of the privileges for a given partition.
|
List<String> |
listPartitionNames(String catName,
String db_name,
String tbl_name,
short max_parts)
Get a partial or complete list of names for partitions of a table.
|
List<String> |
listPartitionNamesPs(String catName,
String db_name,
String tbl_name,
List<String> part_vals,
short max_parts)
Lists partition names that match a given partial specification
|
List<org.apache.hadoop.hive.metastore.api.Partition> |
listPartitionsPsWithAuth(String catName,
String db_name,
String tbl_name,
List<String> part_vals,
short max_parts,
String userName,
List<String> groupNames)
Lists partitions that match a given partial specification and sets their auth privileges.
|
org.apache.hadoop.hive.metastore.api.PartitionValuesResponse |
listPartitionValues(String catName,
String db_name,
String tbl_name,
List<org.apache.hadoop.hive.metastore.api.FieldSchema> cols,
boolean applyDistinct,
String filter,
boolean ascending,
List<org.apache.hadoop.hive.metastore.api.FieldSchema> order,
long maxParts)
Get a list of partition values as one big struct.
|
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listPrincipalDBGrants(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType,
String catName,
String dbName)
For a given principal name and type, list the DB Grants
|
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listPrincipalDBGrantsAll(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
List all DB grants for a given principal.
|
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listPrincipalGlobalGrants(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType) |
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listPrincipalPartitionColumnGrants(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType,
String catName,
String dbName,
String tableName,
List<String> partValues,
String partName,
String columnName)
For a given principal name and type, list the Table Grants
|
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listPrincipalPartitionColumnGrantsAll(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
List all Partition column grants for a given principal
|
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listPrincipalPartitionGrants(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType,
String catName,
String dbName,
String tableName,
List<String> partValues,
String partName)
For a given principal name and type, list the Table Grants
|
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listPrincipalPartitionGrantsAll(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
List all Partition grants for a given principal
|
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listPrincipalTableColumnGrants(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType,
String catName,
String dbName,
String tableName,
String columnName)
For a given principal name and type, list the Table Grants
|
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listPrincipalTableColumnGrantsAll(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
List all Table column grants for a given principal
|
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listPrincipalTableGrantsAll(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
List all Table grants for a given principal
|
List<org.apache.hadoop.hive.metastore.api.RolePrincipalGrant> |
listRoleMembers(String roleName)
Get the role to principal grant mapping for given role
|
List<String> |
listRoleNames() |
List<org.apache.hadoop.hive.metastore.api.Role> |
listRoles(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType) |
List<org.apache.hadoop.hive.metastore.api.RolePrincipalGrant> |
listRolesWithGrants(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType) |
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listTableColumnGrantsAll(String catName,
String dbName,
String tableName,
String columnName)
Find all of the privileges for a given column in a given table.
|
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
listTableGrantsAll(String catName,
String dbName,
String tableName)
Find all of the privileges for a given table
|
List<String> |
listTableNamesByFilter(String catName,
String dbName,
String filter,
short max_tables)
Gets a list of tables based on a filter string and filter type.
|
org.apache.hadoop.hive.metastore.api.Table |
markPartitionForEvent(String catName,
String dbName,
String tblName,
Map<String,String> partVals,
org.apache.hadoop.hive.metastore.api.PartitionEventType evtType) |
boolean |
openTransaction()
Opens a new one or the one already created Every call of this function must
have corresponding commit or rollback function call
|
void |
putFileMetadata(List<Long> fileIds,
List<ByteBuffer> metadata,
org.apache.hadoop.hive.metastore.api.FileMetadataExprType type) |
boolean |
refreshPrivileges(org.apache.hadoop.hive.metastore.api.HiveObjectRef objToRefresh,
String authorizer,
org.apache.hadoop.hive.metastore.api.PrivilegeBag grantPrivileges) |
boolean |
removeMasterKey(Integer keySeq) |
boolean |
removeRole(String roleName) |
boolean |
removeToken(String tokenIdentifier) |
boolean |
revokePrivileges(org.apache.hadoop.hive.metastore.api.PrivilegeBag privileges,
boolean grantOption) |
boolean |
revokeRole(org.apache.hadoop.hive.metastore.api.Role role,
String userName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType,
boolean grantOption) |
void |
rollbackTransaction()
Rolls back the current transaction if it is active
|
void |
setMetaStoreSchemaVersion(String version,
String comment) |
void |
shutdown() |
void |
updateCreationMetadata(String catName,
String dbname,
String tablename,
org.apache.hadoop.hive.metastore.api.CreationMetadata cm)
Update creation metadata for a materialized view.
|
void |
updateMasterKey(Integer seqNo,
String key) |
boolean |
updatePartitionColumnStatistics(org.apache.hadoop.hive.metastore.api.ColumnStatistics statsObj,
List<String> partVals)
Persists the given column statistics object to the metastore
|
boolean |
updateTableColumnStatistics(org.apache.hadoop.hive.metastore.api.ColumnStatistics colStats)
Persists the given column statistics object to the metastore
|
org.apache.hadoop.hive.metastore.api.WMValidateResourcePlanResponse |
validateResourcePlan(String name) |
void |
verifySchema() |
void shutdown()
boolean openTransaction()
boolean commitTransaction()
boolean isActiveTransaction()
void rollbackTransaction()
void createCatalog(org.apache.hadoop.hive.metastore.api.Catalog cat)
throws org.apache.hadoop.hive.metastore.api.MetaException
cat - Catalog to create.org.apache.hadoop.hive.metastore.api.MetaException - if something goes wrong, usually in storing it to the database.void alterCatalog(String catName, org.apache.hadoop.hive.metastore.api.Catalog cat) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidOperationException
catName - name of the catalog to alter.cat - new version of the catalog.org.apache.hadoop.hive.metastore.api.MetaException - something went wrong, usually in the database.org.apache.hadoop.hive.metastore.api.InvalidOperationException - attempt to change something about the catalog that is not
changeable, like the name.org.apache.hadoop.hive.metastore.api.Catalog getCatalog(String catalogName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catalogName - name of the catalog.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no catalog of this name exists.org.apache.hadoop.hive.metastore.api.MetaException - if something goes wrong, usually in reading it from the database.List<String> getCatalogs() throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException - if something goes wrong, usually in reading from the database.void dropCatalog(String catalogName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catalogName - name of the catalog to drop.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no catalog of this name exists.org.apache.hadoop.hive.metastore.api.MetaException - could mean the catalog isn't empty, could mean general database error.void createDatabase(org.apache.hadoop.hive.metastore.api.Database db)
throws org.apache.hadoop.hive.metastore.api.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
db - database to create.org.apache.hadoop.hive.metastore.api.InvalidObjectException - not sure it actually ever throws this.org.apache.hadoop.hive.metastore.api.MetaException - if something goes wrong, usually in writing it to the database.org.apache.hadoop.hive.metastore.api.Database getDatabase(String catalogName, String name) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catalogName - catalog the database is in.name - name of the database.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - if no such database exists.boolean dropDatabase(String catalogName, String dbname) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catalogName - catalog the database is in.dbname - name of the database.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no database in this catalog of this name to droporg.apache.hadoop.hive.metastore.api.MetaException - something went wrong, usually with the database.boolean alterDatabase(String catalogName, String dbname, org.apache.hadoop.hive.metastore.api.Database db) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catalogName - name of the catalog the database is in.dbname - name of the database to alterdb - new version of the database. This should be complete as it will fully replace the
existing db object.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no database of this name exists to alter.org.apache.hadoop.hive.metastore.api.MetaException - something went wrong, usually with the database.List<String> getDatabases(String catalogName, String pattern) throws org.apache.hadoop.hive.metastore.api.MetaException
catalogName - name of the catalog to search for databases inpattern - pattern names should matchorg.apache.hadoop.hive.metastore.api.MetaException - something went wrong, usually with the database.List<String> getAllDatabases(String catalogName) throws org.apache.hadoop.hive.metastore.api.MetaException
catalogName - name of the catalog to search for databases inorg.apache.hadoop.hive.metastore.api.MetaException - something went wrong, usually with the database.boolean createType(org.apache.hadoop.hive.metastore.api.Type type)
org.apache.hadoop.hive.metastore.api.Type getType(String typeName)
boolean dropType(String typeName)
void createTable(org.apache.hadoop.hive.metastore.api.Table tbl)
throws org.apache.hadoop.hive.metastore.api.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionboolean dropTable(String catalogName, String dbName, String tableName) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.InvalidInputException
catalogName - catalog the table is indbName - database the table is intableName - table nameorg.apache.hadoop.hive.metastore.api.MetaException - something went wrong, usually in the RDBMS or storageorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - No table of this nameorg.apache.hadoop.hive.metastore.api.InvalidObjectException - Don't think this is ever actually thrownorg.apache.hadoop.hive.metastore.api.InvalidInputException - Don't think this is ever actually thrownorg.apache.hadoop.hive.metastore.api.Table getTable(String catalogName, String dbName, String tableName) throws org.apache.hadoop.hive.metastore.api.MetaException
catalogName - catalog the table is in.dbName - database the table is in.tableName - table name.org.apache.hadoop.hive.metastore.api.MetaException - something went wrong in the RDBMSboolean addPartition(org.apache.hadoop.hive.metastore.api.Partition part)
throws org.apache.hadoop.hive.metastore.api.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
part - partition to addorg.apache.hadoop.hive.metastore.api.InvalidObjectException - the provided partition object is not valid.org.apache.hadoop.hive.metastore.api.MetaException - error writing to the RDBMS.boolean addPartitions(String catName, String dbName, String tblName, List<org.apache.hadoop.hive.metastore.api.Partition> parts) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog name.dbName - database name.tblName - table name.parts - list of partitions to be added.org.apache.hadoop.hive.metastore.api.InvalidObjectException - never throws this AFAICTorg.apache.hadoop.hive.metastore.api.MetaException - the partitions don't belong to the indicated table or error writing to
the RDBMS.boolean addPartitions(String catName, String dbName, String tblName, PartitionSpecProxy partitionSpec, boolean ifNotExists) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog name.dbName - database name.tblName - table name.partitionSpec - specification for the partitionifNotExists - whether it is in an error if the partition already exists. If true, then
it is not an error if the partition exists, if false, it is.org.apache.hadoop.hive.metastore.api.InvalidObjectException - The passed in partition spec or table specification is invalid.org.apache.hadoop.hive.metastore.api.MetaException - error writing to RDBMS.org.apache.hadoop.hive.metastore.api.Partition getPartition(String catName, String dbName, String tableName, List<String> part_vals) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog name.dbName - database name.tableName - table name.part_vals - partition values for this table.org.apache.hadoop.hive.metastore.api.MetaException - error reading from RDBMS.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no partition matching this specification exists.boolean doesPartitionExist(String catName, String dbName, String tableName, List<String> part_vals) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog name.dbName - database name.tableName - table name.part_vals - list of partition values.org.apache.hadoop.hive.metastore.api.MetaException - failure reading RDBMSorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - this is never thrown.boolean dropPartition(String catName, String dbName, String tableName, List<String> part_vals) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.InvalidInputException
catName - catalog name.dbName - database name.tableName - table name.part_vals - list of partition values.org.apache.hadoop.hive.metastore.api.MetaException - Error accessing the RDBMS.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no partition matching this description existsorg.apache.hadoop.hive.metastore.api.InvalidObjectException - error dropping the statistics for the partitionorg.apache.hadoop.hive.metastore.api.InvalidInputException - error dropping the statistics for the partitionList<org.apache.hadoop.hive.metastore.api.Partition> getPartitions(String catName, String dbName, String tableName, int max) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog name.dbName - database name.tableName - table namemax - maximum number of partitions, or -1 to get all partitions.org.apache.hadoop.hive.metastore.api.MetaException - error access the RDBMS.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such table existsvoid alterTable(String catName, String dbname, String name, org.apache.hadoop.hive.metastore.api.Table newTable) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog the table is in.dbname - database the table is in.name - name of the table.newTable - New table object. Which parts of the table can be altered are
implementation specific.org.apache.hadoop.hive.metastore.api.InvalidObjectException - The new table object is invalid.org.apache.hadoop.hive.metastore.api.MetaException - something went wrong, usually in the RDBMS or storage.void updateCreationMetadata(String catName, String dbname, String tablename, org.apache.hadoop.hive.metastore.api.CreationMetadata cm) throws org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog name.dbname - database name.tablename - table name.cm - new creation metadataorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.List<String> getTables(String catName, String dbName, String pattern) throws org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog to search indbName - database to search inpattern - pattern to matchorg.apache.hadoop.hive.metastore.api.MetaException - failure in querying the RDBMSList<String> getTables(String catName, String dbName, String pattern, TableType tableType) throws org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog to search indbName - database to search inpattern - pattern to matchtableType - type of table to look fororg.apache.hadoop.hive.metastore.api.MetaException - failure in querying the RDBMSList<String> getMaterializedViewsForRewriting(String catName, String dbName) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog namedbName - database nameorg.apache.hadoop.hive.metastore.api.MetaException - error querying the RDBMSorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such databaseList<org.apache.hadoop.hive.metastore.api.TableMeta> getTableMeta(String catName, String dbNames, String tableNames, List<String> tableTypes) throws org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog name to search in. Search must be confined to one catalog.dbNames - databases to search in.tableNames - names of tables to select.tableTypes - types of tables to look for.org.apache.hadoop.hive.metastore.api.MetaException - failure in querying the RDBMS.List<org.apache.hadoop.hive.metastore.api.Table> getTableObjectsByName(String catName, String dbname, List<String> tableNames) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.UnknownDBException
catName - catalog namedbname - The name of the database from which to retrieve the tablestableNames - The names of the tables to retrieve.org.apache.hadoop.hive.metastore.api.MetaException - failure in querying the RDBMS.org.apache.hadoop.hive.metastore.api.UnknownDBExceptionList<String> getAllTables(String catName, String dbName) throws org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog name.dbName - database name.org.apache.hadoop.hive.metastore.api.MetaException - failure in querying the RDBMS.List<String> listTableNamesByFilter(String catName, String dbName, String filter, short max_tables) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.UnknownDBException
catName - catalog namedbName - The name of the database from which you will retrieve the table namesfilter - The filter stringmax_tables - The maximum number of tables returnedorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.UnknownDBExceptionList<String> listPartitionNames(String catName, String db_name, String tbl_name, short max_parts) throws org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog name.db_name - database name.tbl_name - table name.max_parts - maximum number of partitions to retrieve, -1 for all.org.apache.hadoop.hive.metastore.api.MetaException - there was an error accessing the RDBMSorg.apache.hadoop.hive.metastore.api.PartitionValuesResponse listPartitionValues(String catName, String db_name, String tbl_name, List<org.apache.hadoop.hive.metastore.api.FieldSchema> cols, boolean applyDistinct, String filter, boolean ascending, List<org.apache.hadoop.hive.metastore.api.FieldSchema> order, long maxParts) throws org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog name.db_name - database name.tbl_name - table name.cols - partition key columnsapplyDistinct - whether to apply distinct to the listfilter - filter to apply to the partition namesascending - whether to put in ascending orderorder - whether to ordermaxParts - maximum number of parts to return, or -1 for allorg.apache.hadoop.hive.metastore.api.MetaException - error access the RDBMSvoid alterPartition(String catName, String db_name, String tbl_name, List<String> part_vals, org.apache.hadoop.hive.metastore.api.Partition new_part) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog name.db_name - database name.tbl_name - table name.part_vals - partition values that describe the partition.new_part - new partition object. This should be a complete copy of the old with
changes values, not just the parts to update.org.apache.hadoop.hive.metastore.api.InvalidObjectException - No such partition.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.void alterPartitions(String catName, String db_name, String tbl_name, List<List<String>> part_vals_list, List<org.apache.hadoop.hive.metastore.api.Partition> new_parts) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog name.db_name - database name.tbl_name - table name.part_vals_list - list of list of partition values. Each outer list describes one
partition (with its list of partition values).new_parts - list of new partitions. The order must match the old partitions described in
part_vals_list. Each of these should be a complete copy of the new
partition, not just the pieces to update.org.apache.hadoop.hive.metastore.api.InvalidObjectException - One of the indicated partitions does not exist.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.List<org.apache.hadoop.hive.metastore.api.Partition> getPartitionsByFilter(String catName, String dbName, String tblName, String filter, short maxParts) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog namedbName - database nametblName - table namefilter - SQL where clause filtermaxParts - maximum number of partitions to return, or -1 for all.org.apache.hadoop.hive.metastore.api.MetaException - Error accessing the RDBMS or processing the filter.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such table.boolean getPartitionsByExpr(String catName, String dbName, String tblName, byte[] expr, String defaultPartitionName, short maxParts, List<org.apache.hadoop.hive.metastore.api.Partition> result) throws org.apache.thrift.TException
catName - catalog name.dbName - database nametblName - table nameexpr - an already parsed Hive expressiondefaultPartitionName - default name of a partitionmaxParts - maximum number of partitions to return, or -1 for allresult - list to place resulting partitions inorg.apache.thrift.TException - error executing the expressionint getNumPartitionsByFilter(String catName, String dbName, String tblName, String filter) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog name.dbName - database name.tblName - table name.filter - filter from Hive's SQL where clauseorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS or executing the filterorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such tableint getNumPartitionsByExpr(String catName, String dbName, String tblName, byte[] expr) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog name.dbName - database name.tblName - table name.expr - an already parsed Hive expressionorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS or working with the expression.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such table.List<org.apache.hadoop.hive.metastore.api.Partition> getPartitionsByNames(String catName, String dbName, String tblName, List<String> partNames) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog name.dbName - database name.tblName - table name.partNames - list of partition names. These are names not values, so they will include
both the key and the value.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - No such table.org.apache.hadoop.hive.metastore.api.Table markPartitionForEvent(String catName, String dbName, String tblName, Map<String,String> partVals, org.apache.hadoop.hive.metastore.api.PartitionEventType evtType) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.UnknownTableException, org.apache.hadoop.hive.metastore.api.InvalidPartitionException, org.apache.hadoop.hive.metastore.api.UnknownPartitionException
org.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.UnknownTableExceptionorg.apache.hadoop.hive.metastore.api.InvalidPartitionExceptionorg.apache.hadoop.hive.metastore.api.UnknownPartitionExceptionboolean isPartitionMarkedForEvent(String catName, String dbName, String tblName, Map<String,String> partName, org.apache.hadoop.hive.metastore.api.PartitionEventType evtType) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.UnknownTableException, org.apache.hadoop.hive.metastore.api.InvalidPartitionException, org.apache.hadoop.hive.metastore.api.UnknownPartitionException
org.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.UnknownTableExceptionorg.apache.hadoop.hive.metastore.api.InvalidPartitionExceptionorg.apache.hadoop.hive.metastore.api.UnknownPartitionExceptionboolean addRole(String rowName, String ownerName) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionboolean removeRole(String roleName) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionboolean grantRole(org.apache.hadoop.hive.metastore.api.Role role,
String userName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType,
String grantor,
org.apache.hadoop.hive.metastore.api.PrincipalType grantorType,
boolean grantOption)
throws org.apache.hadoop.hive.metastore.api.MetaException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidObjectExceptionboolean revokeRole(org.apache.hadoop.hive.metastore.api.Role role,
String userName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType,
boolean grantOption)
throws org.apache.hadoop.hive.metastore.api.MetaException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet getUserPrivilegeSet(String userName, List<String> groupNames) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet getDBPrivilegeSet(String catName, String dbName, String userName, List<String> groupNames) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog namedbName - database nameuserName - user namegroupNames - list of groups the user is inorg.apache.hadoop.hive.metastore.api.InvalidObjectException - no such databaseorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSorg.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet getTablePrivilegeSet(String catName, String dbName, String tableName, String userName, List<String> groupNames) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog namedbName - database nametableName - table nameuserName - user namegroupNames - list of groups the user is inorg.apache.hadoop.hive.metastore.api.InvalidObjectException - no such tableorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSorg.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet getPartitionPrivilegeSet(String catName, String dbName, String tableName, String partition, String userName, List<String> groupNames) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog namedbName - database nametableName - table namepartition - partition nameuserName - user namegroupNames - list of groups the user is inorg.apache.hadoop.hive.metastore.api.InvalidObjectException - no such partitionorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSorg.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet getColumnPrivilegeSet(String catName, String dbName, String tableName, String partitionName, String columnName, String userName, List<String> groupNames) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog namedbName - database nametableName - table namepartitionName - partition name, or null for table level column permissionscolumnName - column nameuserName - user namegroupNames - list of groups the user is inorg.apache.hadoop.hive.metastore.api.InvalidObjectException - no such table, partition, or columnorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSList<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalGlobalGrants(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalDBGrants(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType, String catName, String dbName)
principalName - principal nameprincipalType - typecatName - catalog namedbName - database nameList<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listAllTableGrants(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType, String catName, String dbName, String tableName)
principalName - principal nameprincipalType - typecatName - catalog namedbName - database nametableName - table nameList<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalPartitionGrants(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType, String catName, String dbName, String tableName, List<String> partValues, String partName)
principalName - principal nameprincipalType - typecatName - catalog namedbName - database nametableName - table namepartName - partition name (not value)List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalTableColumnGrants(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType, String catName, String dbName, String tableName, String columnName)
principalName - principal nameprincipalType - typecatName - catalog namedbName - database nametableName - table namecolumnName - column nameList<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalPartitionColumnGrants(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType, String catName, String dbName, String tableName, List<String> partValues, String partName, String columnName)
principalName - principal nameprincipalType - typecatName - catalog namedbName - database nametableName - table namepartName - partition name (not value)columnName - column nameboolean grantPrivileges(org.apache.hadoop.hive.metastore.api.PrivilegeBag privileges)
throws org.apache.hadoop.hive.metastore.api.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.MetaException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionboolean revokePrivileges(org.apache.hadoop.hive.metastore.api.PrivilegeBag privileges,
boolean grantOption)
throws org.apache.hadoop.hive.metastore.api.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.MetaException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionboolean refreshPrivileges(org.apache.hadoop.hive.metastore.api.HiveObjectRef objToRefresh,
String authorizer,
org.apache.hadoop.hive.metastore.api.PrivilegeBag grantPrivileges)
throws org.apache.hadoop.hive.metastore.api.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.MetaException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.Role getRole(String roleName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionList<org.apache.hadoop.hive.metastore.api.Role> listRoles(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
List<org.apache.hadoop.hive.metastore.api.RolePrincipalGrant> listRolesWithGrants(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
List<org.apache.hadoop.hive.metastore.api.RolePrincipalGrant> listRoleMembers(String roleName)
roleName - org.apache.hadoop.hive.metastore.api.Partition getPartitionWithAuth(String catName, String dbName, String tblName, List<String> partVals, String user_name, List<String> group_names) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidObjectException
catName - catalog name.dbName - database name.tblName - table name.partVals - partition valuesuser_name - user to get privilege information for.group_names - groups to get privilege information for.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such partition existsorg.apache.hadoop.hive.metastore.api.InvalidObjectException - error fetching privilege informationList<org.apache.hadoop.hive.metastore.api.Partition> getPartitionsWithAuth(String catName, String dbName, String tblName, short maxParts, String userName, List<String> groupNames) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidObjectException
catName - catalog name.dbName - database name.tblName - table name.maxParts - maximum number of partitions to fetch, -1 for all partitions.userName - user to get privilege information for.groupNames - groups to get privilege information for.org.apache.hadoop.hive.metastore.api.MetaException - error access the RDBMS.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such table existsorg.apache.hadoop.hive.metastore.api.InvalidObjectException - error fetching privilege information.List<String> listPartitionNamesPs(String catName, String db_name, String tbl_name, List<String> part_vals, short max_parts) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog name.db_name - The name of the database which has the partitionstbl_name - The name of the table which has the partitionspart_vals - A partial list of values for partitions in order of the table's partition keys.
Entries can be empty if you only want to specify latter partitions.max_parts - The maximum number of partitions to returnorg.apache.hadoop.hive.metastore.api.MetaException - error accessing RDBMSorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - No such table existsList<org.apache.hadoop.hive.metastore.api.Partition> listPartitionsPsWithAuth(String catName, String db_name, String tbl_name, List<String> part_vals, short max_parts, String userName, List<String> groupNames) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog name.db_name - The name of the database which has the partitionstbl_name - The name of the table which has the partitionspart_vals - A partial list of values for partitions in order of the table's partition keys
Entries can be empty if you need to specify latter partitions.max_parts - The maximum number of partitions to returnuserName - The user name for the partition for authentication privilegesgroupNames - The groupNames for the partition for authentication privilegesorg.apache.hadoop.hive.metastore.api.MetaException - error access RDBMSorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - No such table existsorg.apache.hadoop.hive.metastore.api.InvalidObjectException - error access privilege informationboolean updateTableColumnStatistics(org.apache.hadoop.hive.metastore.api.ColumnStatistics colStats)
throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.MetaException,
org.apache.hadoop.hive.metastore.api.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.InvalidInputException
colStats - object to persistorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - No such table.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.org.apache.hadoop.hive.metastore.api.InvalidObjectException - the stats object is invalidorg.apache.hadoop.hive.metastore.api.InvalidInputException - unable to record the stats for the tableboolean updatePartitionColumnStatistics(org.apache.hadoop.hive.metastore.api.ColumnStatistics statsObj,
List<String> partVals)
throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.MetaException,
org.apache.hadoop.hive.metastore.api.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.InvalidInputException
statsObj - object to persistpartVals - partition values to persist the stats fororg.apache.hadoop.hive.metastore.api.NoSuchObjectException - No such table.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.org.apache.hadoop.hive.metastore.api.InvalidObjectException - the stats object is invalidorg.apache.hadoop.hive.metastore.api.InvalidInputException - unable to record the stats for the tableorg.apache.hadoop.hive.metastore.api.ColumnStatistics getTableColumnStatistics(String catName, String dbName, String tableName, List<String> colName) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog name.dbName - name of the database, defaults to current databasetableName - name of the tablecolName - names of the columns for which statistics is requestedorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - No such tableorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSList<org.apache.hadoop.hive.metastore.api.ColumnStatistics> getPartitionColumnStatistics(String catName, String dbName, String tblName, List<String> partNames, List<String> colNames) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog name.dbName - database name.tblName - table name.partNames - list of partition names. These are names so must be key1=val1[/key2=val2...]colNames - list of columns to get stats fororg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such partition.boolean deletePartitionColumnStatistics(String catName, String dbName, String tableName, String partName, List<String> partVals, String colName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.InvalidInputException
catName - catalog name.dbName - database name.tableName - table name.partName - partition name.partVals - partition values.colName - column name.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such partitionorg.apache.hadoop.hive.metastore.api.MetaException - error access the RDBMSorg.apache.hadoop.hive.metastore.api.InvalidObjectException - error dropping the statsorg.apache.hadoop.hive.metastore.api.InvalidInputException - bad input, such as null table or database name.boolean deleteTableColumnStatistics(String catName, String dbName, String tableName, String colName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.InvalidInputException
catName - catalog namedbName - database nametableName - table namecolName - column name. Null to delete stats for all columns in the table.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such table or column.org.apache.hadoop.hive.metastore.api.MetaException - error access the RDBMS.org.apache.hadoop.hive.metastore.api.InvalidObjectException - error dropping the statsorg.apache.hadoop.hive.metastore.api.InvalidInputException - bad inputs, such as null table name.long cleanupEvents()
boolean removeToken(String tokenIdentifier)
int addMasterKey(String key) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaExceptionvoid updateMasterKey(Integer seqNo, String key) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionboolean removeMasterKey(Integer keySeq)
String[] getMasterKeys()
void verifySchema()
throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaExceptionString getMetaStoreSchemaVersion() throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaExceptionvoid setMetaStoreSchemaVersion(String version, String comment) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaExceptionvoid dropPartitions(String catName, String dbName, String tblName, List<String> partNames) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog name.dbName - database name.tblName - table namepartNames - list of partition names.org.apache.hadoop.hive.metastore.api.MetaException - error access RDBMS or storage.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - One or more of the partitions does not exist.List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalDBGrantsAll(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
principalName - principal nameprincipalType - typeList<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalTableGrantsAll(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
principalName - principal nameprincipalType - typeList<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalPartitionGrantsAll(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
principalName - principal nameprincipalType - typeList<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalTableColumnGrantsAll(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
principalName - principal nameprincipalType - typeList<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalPartitionColumnGrantsAll(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
principalName - principal nameprincipalType - typeList<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listGlobalGrantsAll()
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listDBGrantsAll(String catName, String dbName)
catName - catalog namedbName - database nameList<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPartitionColumnGrantsAll(String catName, String dbName, String tableName, String partitionName, String columnName)
catName - catalog namedbName - database nametableName - table namepartitionName - partition name (not value)columnName - column nameList<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listTableGrantsAll(String catName, String dbName, String tableName)
catName - catalog namedbName - database nametableName - table nameList<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPartitionGrantsAll(String catName, String dbName, String tableName, String partitionName)
catName - catalog namedbName - database nametableName - table namepartitionName - partition name (not value)List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listTableColumnGrantsAll(String catName, String dbName, String tableName, String columnName)
catName - catalog namedbName - database nametableName - table namecolumnName - column namevoid createFunction(org.apache.hadoop.hive.metastore.api.Function func)
throws org.apache.hadoop.hive.metastore.api.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
func - function to createorg.apache.hadoop.hive.metastore.api.InvalidObjectException - incorrectly specified functionorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSvoid alterFunction(String catName, String dbName, String funcName, org.apache.hadoop.hive.metastore.api.Function newFunction) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
dbName - database namefuncName - function namenewFunction - new function specificationorg.apache.hadoop.hive.metastore.api.InvalidObjectException - no such function, or incorrectly specified new functionorg.apache.hadoop.hive.metastore.api.MetaException - incorrectly specified functionvoid dropFunction(String catName, String dbName, String funcName) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.InvalidInputException
dbName - database namefuncName - function nameorg.apache.hadoop.hive.metastore.api.MetaException - incorrectly specified functionorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such functionorg.apache.hadoop.hive.metastore.api.InvalidObjectException - not sure when this is thrownorg.apache.hadoop.hive.metastore.api.InvalidInputException - not sure when this is thrownorg.apache.hadoop.hive.metastore.api.Function getFunction(String catName, String dbName, String funcName) throws org.apache.hadoop.hive.metastore.api.MetaException
dbName - database namefuncName - function nameorg.apache.hadoop.hive.metastore.api.MetaException - incorrectly specified functionList<org.apache.hadoop.hive.metastore.api.Function> getAllFunctions(String catName) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException - incorrectly specified functionList<String> getFunctions(String catName, String dbName, String pattern) throws org.apache.hadoop.hive.metastore.api.MetaException
dbName - database namepattern - pattern to matchorg.apache.hadoop.hive.metastore.api.MetaException - incorrectly specified functionorg.apache.hadoop.hive.metastore.api.AggrStats get_aggr_stats_for(String catName, String dbName, String tblName, List<String> partNames, List<String> colNames) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog name.dbName - database name.tblName - table name.partNames - list of partition names. These are the names of the partitions, not
values.colNames - list of column namesorg.apache.hadoop.hive.metastore.api.MetaException - error accessing RDBMSorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such table or partitionList<MetaStoreUtils.ColStatsObjWithSourceInfo> getPartitionColStatsForDatabase(String catName, String dbName) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog namedbName - database nameorg.apache.hadoop.hive.metastore.api.MetaException - error accessing RDBMSorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such databaseorg.apache.hadoop.hive.metastore.api.NotificationEventResponse getNextNotification(org.apache.hadoop.hive.metastore.api.NotificationEventRequest rqst)
rqst - Request containing information on the last processed notification.void addNotificationEvent(org.apache.hadoop.hive.metastore.api.NotificationEvent event)
event - the notification to addvoid cleanNotificationEvents(int olderThan)
olderThan - Remove any events older than a given number of secondsorg.apache.hadoop.hive.metastore.api.CurrentNotificationEventId getCurrentNotificationEventId()
org.apache.hadoop.hive.metastore.api.NotificationEventsCountResponse getNotificationEventsCount(org.apache.hadoop.hive.metastore.api.NotificationEventsCountRequest rqst)
void flushCache()
ByteBuffer[] getFileMetadata(List<Long> fileIds) throws org.apache.hadoop.hive.metastore.api.MetaException
fileIds - List of file IDs from the filesystem.org.apache.hadoop.hive.metastore.api.MetaExceptionvoid putFileMetadata(List<Long> fileIds, List<ByteBuffer> metadata, org.apache.hadoop.hive.metastore.api.FileMetadataExprType type) throws org.apache.hadoop.hive.metastore.api.MetaException
fileIds - List of file IDs from the filesystem.metadata - Metadata buffers corresponding to fileIds in the list.type - The type; determines the class that can do additiona processing for metadata.org.apache.hadoop.hive.metastore.api.MetaExceptionboolean isFileMetadataSupported()
void getFileMetadataByExpr(List<Long> fileIds, org.apache.hadoop.hive.metastore.api.FileMetadataExprType type, byte[] expr, ByteBuffer[] metadatas, ByteBuffer[] exprResults, boolean[] eliminated) throws org.apache.hadoop.hive.metastore.api.MetaException
fileIds - List of file IDs from the filesystem.expr - Format-specific serialized expression applicable to the files' metadatas.type - Expression type; used to determine the class that handles the metadata.metadatas - Output parameter; fileIds-sized array to receive the metadatas
for corresponding files, if any.exprResults - Output parameter; fileIds-sized array to receive the format-specific
expression results for the corresponding files.eliminated - Output parameter; fileIds-sized array to receive the indication of whether
the corresponding files are entirely eliminated by the expression.org.apache.hadoop.hive.metastore.api.MetaExceptionFileMetadataHandler getFileMetadataHandler(org.apache.hadoop.hive.metastore.api.FileMetadataExprType type)
@InterfaceStability.Evolving
int getTableCount()
throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException@InterfaceStability.Evolving
int getPartitionCount()
throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException@InterfaceStability.Evolving
int getDatabaseCount()
throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaExceptionList<org.apache.hadoop.hive.metastore.api.SQLPrimaryKey> getPrimaryKeys(String catName, String db_name, String tbl_name) throws org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog namedb_name - database nametbl_name - table nameorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSList<org.apache.hadoop.hive.metastore.api.SQLForeignKey> getForeignKeys(String catName, String parent_db_name, String parent_tbl_name, String foreign_db_name, String foreign_tbl_name) throws org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog name.parent_db_name - Database the table referred to is in. This can be null to match all
databases.parent_tbl_name - Table that is referred to. This can be null to match all tables.foreign_db_name - Database the table with the foreign key is in.foreign_tbl_name - Table with the foreign key.org.apache.hadoop.hive.metastore.api.MetaException - error access the RDBMS.List<org.apache.hadoop.hive.metastore.api.SQLUniqueConstraint> getUniqueConstraints(String catName, String db_name, String tbl_name) throws org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog name.db_name - database name.tbl_name - table name.org.apache.hadoop.hive.metastore.api.MetaException - error access the RDBMS.List<org.apache.hadoop.hive.metastore.api.SQLNotNullConstraint> getNotNullConstraints(String catName, String db_name, String tbl_name) throws org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog name.db_name - database name.tbl_name - table name.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.List<org.apache.hadoop.hive.metastore.api.SQLDefaultConstraint> getDefaultConstraints(String catName, String db_name, String tbl_name) throws org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog namedb_name - database nametbl_name - table nameorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSList<org.apache.hadoop.hive.metastore.api.SQLCheckConstraint> getCheckConstraints(String catName, String db_name, String tbl_name) throws org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog name.db_name - database nametbl_name - table nameorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSList<String> createTableWithConstraints(org.apache.hadoop.hive.metastore.api.Table tbl, List<org.apache.hadoop.hive.metastore.api.SQLPrimaryKey> primaryKeys, List<org.apache.hadoop.hive.metastore.api.SQLForeignKey> foreignKeys, List<org.apache.hadoop.hive.metastore.api.SQLUniqueConstraint> uniqueConstraints, List<org.apache.hadoop.hive.metastore.api.SQLNotNullConstraint> notNullConstraints, List<org.apache.hadoop.hive.metastore.api.SQLDefaultConstraint> defaultConstraints, List<org.apache.hadoop.hive.metastore.api.SQLCheckConstraint> checkConstraints) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
tbl - table definitionprimaryKeys - primary key definition, or nullforeignKeys - foreign key definition, or nulluniqueConstraints - unique constraints definition, or nullnotNullConstraints - not null constraints definition, or nulldefaultConstraints - default values definition, or nullorg.apache.hadoop.hive.metastore.api.InvalidObjectException - one of the provided objects is malformed.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSdefault void dropConstraint(String catName, String dbName, String tableName, String constraintName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog namedbName - database nametableName - table nameconstraintName - name of the constraintorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no constraint of this name existsvoid dropConstraint(String catName, String dbName, String tableName, String constraintName, boolean missingOk) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog namedbName - database nametableName - table nameconstraintName - name of the constraintmissingOk - if true, it is not an error if there is no constraint of this name. If
false and there is no constraint of this name an exception will be thrown.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no constraint of this name exists and missingOk = falseList<String> addPrimaryKeys(List<org.apache.hadoop.hive.metastore.api.SQLPrimaryKey> pks) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
pks - Columns in the primary key.org.apache.hadoop.hive.metastore.api.InvalidObjectException - The SQLPrimaryKeys list is malformedorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDMBSList<String> addForeignKeys(List<org.apache.hadoop.hive.metastore.api.SQLForeignKey> fks) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
fks - foreign key specificationorg.apache.hadoop.hive.metastore.api.InvalidObjectException - the specification is malformed.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.List<String> addUniqueConstraints(List<org.apache.hadoop.hive.metastore.api.SQLUniqueConstraint> uks) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
uks - unique constraints specificationorg.apache.hadoop.hive.metastore.api.InvalidObjectException - the specification is malformed.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.List<String> addNotNullConstraints(List<org.apache.hadoop.hive.metastore.api.SQLNotNullConstraint> nns) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
nns - not null constraint specificationsorg.apache.hadoop.hive.metastore.api.InvalidObjectException - the specification is malformed.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.List<String> addDefaultConstraints(List<org.apache.hadoop.hive.metastore.api.SQLDefaultConstraint> dv) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
dv - list of default valuesorg.apache.hadoop.hive.metastore.api.InvalidObjectException - the specification is malformed.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.List<String> addCheckConstraints(List<org.apache.hadoop.hive.metastore.api.SQLCheckConstraint> cc) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
cc - check constraints to addorg.apache.hadoop.hive.metastore.api.InvalidObjectException - the specification is malformedorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSString getMetastoreDbUuid() throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaExceptionvoid createResourcePlan(org.apache.hadoop.hive.metastore.api.WMResourcePlan resourcePlan,
String copyFrom,
int defaultPoolSize)
throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException,
org.apache.hadoop.hive.metastore.api.MetaException,
org.apache.hadoop.hive.metastore.api.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.AlreadyExistsExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.WMFullResourcePlan getResourcePlan(String name) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionList<org.apache.hadoop.hive.metastore.api.WMResourcePlan> getAllResourcePlans() throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.WMFullResourcePlan alterResourcePlan(String name, org.apache.hadoop.hive.metastore.api.WMNullableResourcePlan resourcePlan, boolean canActivateDisabled, boolean canDeactivate, boolean isReplace) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.AlreadyExistsExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.WMFullResourcePlan getActiveResourcePlan()
throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.WMValidateResourcePlanResponse validateResourcePlan(String name) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionvoid dropResourcePlan(String name) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionvoid createWMTrigger(org.apache.hadoop.hive.metastore.api.WMTrigger trigger)
throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.InvalidOperationException,
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.AlreadyExistsExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionvoid alterWMTrigger(org.apache.hadoop.hive.metastore.api.WMTrigger trigger)
throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.InvalidOperationException,
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionvoid dropWMTrigger(String resourcePlanName, String triggerName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionList<org.apache.hadoop.hive.metastore.api.WMTrigger> getTriggersForResourcePlan(String resourcePlanName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionvoid createPool(org.apache.hadoop.hive.metastore.api.WMPool pool)
throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.InvalidOperationException,
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.AlreadyExistsExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionvoid alterPool(org.apache.hadoop.hive.metastore.api.WMNullablePool pool,
String poolPath)
throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.InvalidOperationException,
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.AlreadyExistsExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionvoid dropWMPool(String resourcePlanName, String poolPath) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionvoid createOrUpdateWMMapping(org.apache.hadoop.hive.metastore.api.WMMapping mapping,
boolean update)
throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.InvalidOperationException,
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.AlreadyExistsExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionvoid dropWMMapping(org.apache.hadoop.hive.metastore.api.WMMapping mapping)
throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.InvalidOperationException,
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionvoid createWMTriggerToPoolMapping(String resourcePlanName, String triggerName, String poolPath) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.AlreadyExistsExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionvoid dropWMTriggerToPoolMapping(String resourcePlanName, String triggerName, String poolPath) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionvoid createISchema(org.apache.hadoop.hive.metastore.api.ISchema schema)
throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException,
org.apache.hadoop.hive.metastore.api.MetaException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
schema - schema to createorg.apache.hadoop.hive.metastore.api.AlreadyExistsException - there's already a schema with this nameorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionvoid alterISchema(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName,
org.apache.hadoop.hive.metastore.api.ISchema newSchema)
throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
schemaName - name of the schemanewSchema - new schema objectorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no function with this name existsorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionorg.apache.hadoop.hive.metastore.api.ISchema getISchema(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName)
throws org.apache.hadoop.hive.metastore.api.MetaException
schemaName - schema descriptororg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionvoid dropISchema(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName)
throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
schemaName - schema descriptororg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no schema of this name existsorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionvoid addSchemaVersion(org.apache.hadoop.hive.metastore.api.SchemaVersion schemaVersion)
throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException,
org.apache.hadoop.hive.metastore.api.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
schemaVersion - version numberorg.apache.hadoop.hive.metastore.api.AlreadyExistsException - a version of the schema with the same version number already
exists.org.apache.hadoop.hive.metastore.api.InvalidObjectException - the passed in SchemaVersion object has problems.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - no schema with the passed in name exists.org.apache.hadoop.hive.metastore.api.MetaException - general database exceptionvoid alterSchemaVersion(org.apache.hadoop.hive.metastore.api.SchemaVersionDescriptor version,
org.apache.hadoop.hive.metastore.api.SchemaVersion newVersion)
throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
version - version descriptor for the schemanewVersion - altered SchemaVersionorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such version of the named schema existsorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionorg.apache.hadoop.hive.metastore.api.SchemaVersion getSchemaVersion(org.apache.hadoop.hive.metastore.api.SchemaVersionDescriptor version)
throws org.apache.hadoop.hive.metastore.api.MetaException
version - version descriptor for the schemaorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionorg.apache.hadoop.hive.metastore.api.SchemaVersion getLatestSchemaVersion(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName)
throws org.apache.hadoop.hive.metastore.api.MetaException
schemaName - name of the schemaorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionList<org.apache.hadoop.hive.metastore.api.SchemaVersion> getAllSchemaVersion(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName) throws org.apache.hadoop.hive.metastore.api.MetaException
schemaName - name of the schemaorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionList<org.apache.hadoop.hive.metastore.api.SchemaVersion> getSchemaVersionsByColumns(String colName, String colNamespace, String type) throws org.apache.hadoop.hive.metastore.api.MetaException
colName - column name. Null is ok, which will cause this field to not be used in the
query.colNamespace - column namespace. Null is ok, which will cause this field to not be
used in the query.type - column type. Null is ok, which will cause this field to not be used in the
query.org.apache.hadoop.hive.metastore.api.MetaException - general database exceptionvoid dropSchemaVersion(org.apache.hadoop.hive.metastore.api.SchemaVersionDescriptor version)
throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
version - version descriptor for the schemaorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such version of the named schema existsorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionorg.apache.hadoop.hive.metastore.api.SerDeInfo getSerDeInfo(String serDeName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
serDeName - name of the SerDeorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no serde with this name existsorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionvoid addSerde(org.apache.hadoop.hive.metastore.api.SerDeInfo serde)
throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException,
org.apache.hadoop.hive.metastore.api.MetaException
serde - serde to addorg.apache.hadoop.hive.metastore.api.AlreadyExistsException - a serde of this name already existsorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionvoid addRuntimeStat(org.apache.hadoop.hive.metastore.api.RuntimeStat stat)
throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaExceptionList<org.apache.hadoop.hive.metastore.api.RuntimeStat> getRuntimeStats(int maxEntries, int maxCreateTime) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaExceptionint deleteRuntimeStats(int maxRetainSecs)
throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaExceptionList<MetaStoreUtils.FullTableName> getTableNamesWithStats() throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionList<MetaStoreUtils.FullTableName> getAllTableNamesForStats() throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionMap<String,List<String>> getPartitionColsWithStats(String catName, String dbName, String tableName) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionCopyright © 2019 The Apache Software Foundation. All Rights Reserved.