RawStore.CanNotRetry| Constructor and Description |
|---|
CachedStore() |
| Modifier and Type | Method and Description |
|---|---|
List<String> |
addCheckConstraints(List<org.apache.hadoop.hive.metastore.api.SQLCheckConstraint> nns)
Add check constraints to a table
|
List<String> |
addDefaultConstraints(List<org.apache.hadoop.hive.metastore.api.SQLDefaultConstraint> nns)
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 catName,
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 dbName,
String tblName,
List<String> partVals,
org.apache.hadoop.hive.metastore.api.Partition newPart)
Alter a partition.
|
void |
alterPartitions(String catName,
String dbName,
String tblName,
List<List<String>> partValsList,
List<org.apache.hadoop.hive.metastore.api.Partition> newParts)
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 tblName,
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 tblName,
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 tblName,
String colName)
Delete statistics for a single column or all columns in a table.
|
boolean |
doesPartitionExist(String catName,
String dbName,
String tblName,
List<String> part_vals)
Check whether a partition exists.
|
void |
dropCatalog(String catalogName)
Drop a catalog.
|
void |
dropConstraint(String catName,
String dbName,
String tableName,
String constraintName,
boolean missingOk)
Drop a constraint, any constraint.
|
boolean |
dropDatabase(String catName,
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 tblName,
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 catName,
String dbName,
String tblName)
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 catName)
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() |
long |
getCacheUpdateCount() |
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.conf.Configuration |
getConf() |
org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId |
getCurrentNotificationEventId()
Get the last issued notification event id.
|
org.apache.hadoop.hive.metastore.api.Database |
getDatabase(String catName,
String dbName)
Get a database.
|
int |
getDatabaseCount()
Gets total number of databases.
|
List<String> |
getDatabases(String catName,
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 tblName,
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 tblName,
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 userName,
List<String> groupNames)
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.
|
RawStore |
getRawStore() |
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 catName,
String dbName,
String tblName)
Get a table object.
|
org.apache.hadoop.hive.metastore.api.ColumnStatistics |
getTableColumnStatistics(String catName,
String dbName,
String tblName,
List<String> colNames)
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> tblNames) |
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 dbName,
String tblName,
short max_parts)
Get a partial or complete list of names for partitions of a table.
|
List<String> |
listPartitionNamesPs(String catName,
String dbName,
String tblName,
List<String> partVals,
short maxParts)
Lists partition names that match a given partial specification
|
List<org.apache.hadoop.hive.metastore.api.Partition> |
listPartitionsPsWithAuth(String catName,
String dbName,
String tblName,
List<String> partVals,
short maxParts,
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 |
setConf(org.apache.hadoop.conf.Configuration conf) |
void |
setMetaStoreSchemaVersion(String version,
String comment) |
void |
setRawStore(RawStore rawStore) |
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 colStats,
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() |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitdropConstraintpublic void setConf(org.apache.hadoop.conf.Configuration conf)
setConf in interface org.apache.hadoop.conf.Configurablepublic org.apache.hadoop.conf.Configuration getConf()
getConf in interface org.apache.hadoop.conf.Configurablepublic boolean openTransaction()
RawStoreopenTransaction in interface RawStorepublic boolean commitTransaction()
RawStorecommitTransaction in interface RawStorepublic boolean isActiveTransaction()
isActiveTransaction in interface RawStorepublic void rollbackTransaction()
RawStorerollbackTransaction in interface RawStorepublic void createCatalog(org.apache.hadoop.hive.metastore.api.Catalog cat)
throws org.apache.hadoop.hive.metastore.api.MetaException
RawStorecreateCatalog in interface RawStorecat - Catalog to create.org.apache.hadoop.hive.metastore.api.MetaException - if something goes wrong, usually in storing it to the database.public 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
RawStorealterCatalog in interface RawStorecatName - 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.public 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
RawStoregetCatalog in interface RawStorecatalogName - 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.public List<String> getCatalogs() throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetCatalogs in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaException - if something goes wrong, usually in reading from the database.public void dropCatalog(String catalogName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
RawStoredropCatalog in interface RawStorecatalogName - 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.public 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
RawStorecreateDatabase in interface RawStoredb - 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.public org.apache.hadoop.hive.metastore.api.Database getDatabase(String catName, String dbName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException
RawStoregetDatabase in interface RawStorecatName - catalog the database is in.dbName - name of the database.org.apache.hadoop.hive.metastore.api.NoSuchObjectException - if no such database exists.public boolean dropDatabase(String catName, String dbName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
RawStoredropDatabase in interface RawStorecatName - 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.public boolean alterDatabase(String catName, 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
RawStorealterDatabase in interface RawStorecatName - 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.public List<String> getDatabases(String catName, String pattern) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetDatabases in interface RawStorecatName - 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.public List<String> getAllDatabases(String catName) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetAllDatabases in interface RawStorecatName - name of the catalog to search for databases inorg.apache.hadoop.hive.metastore.api.MetaException - something went wrong, usually with the database.public boolean createType(org.apache.hadoop.hive.metastore.api.Type type)
createType in interface RawStorepublic org.apache.hadoop.hive.metastore.api.Type getType(String typeName)
public 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
createTable in interface RawStoreorg.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic boolean dropTable(String catName, String dbName, String tblName) 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
RawStoredropTable in interface RawStorecatName - catalog the table is indbName - database the table is intblName - 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 thrownpublic org.apache.hadoop.hive.metastore.api.Table getTable(String catName, String dbName, String tblName) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetTable in interface RawStorecatName - catalog the table is in.dbName - database the table is in.tblName - table name.org.apache.hadoop.hive.metastore.api.MetaException - something went wrong in the RDBMSpublic boolean addPartition(org.apache.hadoop.hive.metastore.api.Partition part)
throws org.apache.hadoop.hive.metastore.api.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
RawStoreaddPartition in interface RawStorepart - 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.public 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
RawStoreaddPartitions in interface RawStorecatName - 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.public 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
RawStoreaddPartitions in interface RawStorecatName - 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.public org.apache.hadoop.hive.metastore.api.Partition getPartition(String catName, String dbName, String tblName, List<String> part_vals) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
RawStoregetPartition in interface RawStorecatName - catalog name.dbName - database name.tblName - 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.public boolean doesPartitionExist(String catName, String dbName, String tblName, List<String> part_vals) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
RawStoredoesPartitionExist in interface RawStorecatName - catalog name.dbName - database name.tblName - 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.public boolean dropPartition(String catName, String dbName, String tblName, 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
RawStoredropPartition in interface RawStorecatName - catalog name.dbName - database name.tblName - 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 partitionpublic void 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
RawStoredropPartitions in interface RawStorecatName - 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.public List<org.apache.hadoop.hive.metastore.api.Partition> getPartitions(String catName, String dbName, String tblName, int max) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
RawStoregetPartitions in interface RawStorecatName - catalog name.dbName - database name.tblName - 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 existspublic void alterTable(String catName, String dbName, String tblName, org.apache.hadoop.hive.metastore.api.Table newTable) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
RawStorealterTable in interface RawStorecatName - catalog the table is in.dbName - database the table is in.tblName - 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.public void updateCreationMetadata(String catName, String dbname, String tablename, org.apache.hadoop.hive.metastore.api.CreationMetadata cm) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoreupdateCreationMetadata in interface RawStorecatName - catalog name.dbname - database name.tablename - table name.cm - new creation metadataorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.public List<String> getTables(String catName, String dbName, String pattern) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStorepublic List<String> getTables(String catName, String dbName, String pattern, TableType tableType) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetTables in interface RawStorecatName - 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 RDBMSpublic List<String> getMaterializedViewsForRewriting(String catName, String dbName) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
RawStoregetMaterializedViewsForRewriting in interface RawStorecatName - catalog namedbName - database nameorg.apache.hadoop.hive.metastore.api.MetaException - error querying the RDBMSorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such databasepublic List<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
getTableMeta in interface RawStorecatName - 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.public List<org.apache.hadoop.hive.metastore.api.Table> getTableObjectsByName(String catName, String dbName, List<String> tblNames) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.UnknownDBException
getTableObjectsByName in interface RawStorecatName - catalog namedbName - The name of the database from which to retrieve the tablestblNames - 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.UnknownDBExceptionpublic List<String> getAllTables(String catName, String dbName) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetAllTables in interface RawStorecatName - catalog name.dbName - database name.org.apache.hadoop.hive.metastore.api.MetaException - failure in querying the RDBMS.public 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
RawStorelistTableNamesByFilter in interface RawStorecatName - 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.UnknownDBExceptionpublic List<String> listPartitionNames(String catName, String dbName, String tblName, short max_parts) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStorelistPartitionNames in interface RawStorecatName - catalog name.dbName - database name.tblName - 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 RDBMSpublic 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) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStorelistPartitionValues in interface RawStorecatName - 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 RDBMSpublic void alterPartition(String catName, String dbName, String tblName, List<String> partVals, org.apache.hadoop.hive.metastore.api.Partition newPart) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
RawStorealterPartition in interface RawStorecatName - catalog name.dbName - database name.tblName - table name.partVals - partition values that describe the partition.newPart - 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.public void alterPartitions(String catName, String dbName, String tblName, List<List<String>> partValsList, List<org.apache.hadoop.hive.metastore.api.Partition> newParts) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
RawStorealterPartitions in interface RawStorecatName - catalog name.dbName - database name.tblName - table name.partValsList - list of list of partition values. Each outer list describes one
partition (with its list of partition values).newParts - 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.public 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
RawStoregetPartitionsByFilter in interface RawStorecatName - 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.public 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
RawStoregetPartitionsByExpr in interface RawStorecatName - 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 expressionpublic int getNumPartitionsByFilter(String catName, String dbName, String tblName, String filter) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
RawStoregetNumPartitionsByFilter in interface RawStorecatName - 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 tablepublic int getNumPartitionsByExpr(String catName, String dbName, String tblName, byte[] expr) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
RawStoregetNumPartitionsByExpr in interface RawStorecatName - 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.public 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
RawStoregetPartitionsByNames in interface RawStorecatName - 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.public 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
markPartitionForEvent in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.UnknownTableExceptionorg.apache.hadoop.hive.metastore.api.InvalidPartitionExceptionorg.apache.hadoop.hive.metastore.api.UnknownPartitionExceptionpublic boolean 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
isPartitionMarkedForEvent in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.UnknownTableExceptionorg.apache.hadoop.hive.metastore.api.InvalidPartitionExceptionorg.apache.hadoop.hive.metastore.api.UnknownPartitionExceptionpublic boolean 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
public boolean removeRole(String roleName) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
removeRole in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionpublic 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)
throws org.apache.hadoop.hive.metastore.api.MetaException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.InvalidObjectException
public boolean 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
revokeRole in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionpublic org.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
getUserPrivilegeSet in interface RawStoreorg.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic org.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
RawStoregetDBPrivilegeSet in interface RawStorecatName - 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 RDBMSpublic org.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
RawStoregetTablePrivilegeSet in interface RawStorecatName - 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 RDBMSpublic org.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
RawStoregetPartitionPrivilegeSet in interface RawStorecatName - 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 RDBMSpublic org.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
RawStoregetColumnPrivilegeSet in interface RawStorecatName - 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 RDBMSpublic List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalGlobalGrants(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
listPrincipalGlobalGrants in interface RawStorepublic List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalDBGrants(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType, String catName, String dbName)
RawStorelistPrincipalDBGrants in interface RawStoreprincipalName - principal nameprincipalType - typecatName - catalog namedbName - database namepublic 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)
RawStorelistAllTableGrants in interface RawStoreprincipalName - principal nameprincipalType - typecatName - catalog namedbName - database nametableName - table namepublic 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)
RawStorelistPrincipalPartitionGrants in interface RawStoreprincipalName - principal nameprincipalType - typecatName - catalog namedbName - database nametableName - table namepartName - partition name (not value)public 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)
RawStorelistPrincipalTableColumnGrants in interface RawStoreprincipalName - principal nameprincipalType - typecatName - catalog namedbName - database nametableName - table namecolumnName - column namepublic 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)
RawStorelistPrincipalPartitionColumnGrants in interface RawStoreprincipalName - principal nameprincipalType - typecatName - catalog namedbName - database nametableName - table namepartName - partition name (not value)columnName - column namepublic boolean 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
grantPrivileges in interface RawStoreorg.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionpublic boolean 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
revokePrivileges in interface RawStoreorg.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionpublic boolean 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
refreshPrivileges in interface RawStoreorg.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionpublic org.apache.hadoop.hive.metastore.api.Role getRole(String roleName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException
public List<String> listRoleNames()
listRoleNames in interface RawStorepublic List<org.apache.hadoop.hive.metastore.api.Role> listRoles(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
public List<org.apache.hadoop.hive.metastore.api.RolePrincipalGrant> listRolesWithGrants(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
listRolesWithGrants in interface RawStorepublic List<org.apache.hadoop.hive.metastore.api.RolePrincipalGrant> listRoleMembers(String roleName)
RawStorelistRoleMembers in interface RawStorepublic org.apache.hadoop.hive.metastore.api.Partition getPartitionWithAuth(String catName, String dbName, String tblName, List<String> partVals, 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
RawStoregetPartitionWithAuth in interface RawStorecatName - catalog name.dbName - database name.tblName - table name.partVals - partition valuesuserName - user to get privilege information for.groupNames - 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 informationpublic List<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
RawStoregetPartitionsWithAuth in interface RawStorecatName - 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.public List<String> listPartitionNamesPs(String catName, String dbName, String tblName, List<String> partVals, short maxParts) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
RawStorelistPartitionNamesPs in interface RawStorecatName - catalog name.dbName - The name of the database which has the partitionstblName - The name of the table which has the partitionspartVals - 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.maxParts - 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 existspublic List<org.apache.hadoop.hive.metastore.api.Partition> listPartitionsPsWithAuth(String catName, String dbName, String tblName, List<String> partVals, short maxParts, 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
RawStorelistPartitionsPsWithAuth in interface RawStorecatName - catalog name.dbName - The name of the database which has the partitionstblName - The name of the table which has the partitionspartVals - 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.maxParts - 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.InvalidObjectException - error access privilege informationorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - No such table existspublic boolean 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
RawStoreupdateTableColumnStatistics in interface RawStorecolStats - 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 tablepublic org.apache.hadoop.hive.metastore.api.ColumnStatistics getTableColumnStatistics(String catName, String dbName, String tblName, List<String> colNames) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
RawStoregetTableColumnStatistics in interface RawStorecatName - catalog name.dbName - name of the database, defaults to current databasetblName - name of the tablecolNames - names of the columns for which statistics is requestedorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - No such tablepublic boolean deleteTableColumnStatistics(String catName, String dbName, String tblName, 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
RawStoredeleteTableColumnStatistics in interface RawStorecatName - catalog namedbName - database nametblName - 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.public boolean updatePartitionColumnStatistics(org.apache.hadoop.hive.metastore.api.ColumnStatistics colStats,
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
RawStoreupdatePartitionColumnStatistics in interface RawStorecolStats - 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 tablepublic List<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
RawStoregetPartitionColumnStatistics in interface RawStorecatName - 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.public boolean deletePartitionColumnStatistics(String catName, String dbName, String tblName, 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
RawStoredeletePartitionColumnStatistics in interface RawStorecatName - catalog name.dbName - database name.tblName - 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.public org.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
RawStoreget_aggr_stats_for in interface RawStorecatName - 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 partitionpublic long cleanupEvents()
cleanupEvents in interface RawStorepublic boolean removeToken(String tokenIdentifier)
removeToken in interface RawStorepublic List<String> getAllTokenIdentifiers()
getAllTokenIdentifiers in interface RawStorepublic int addMasterKey(String key) throws org.apache.hadoop.hive.metastore.api.MetaException
addMasterKey in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic void updateMasterKey(Integer seqNo, String key) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
updateMasterKey in interface RawStoreorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic boolean removeMasterKey(Integer keySeq)
removeMasterKey in interface RawStorepublic String[] getMasterKeys()
getMasterKeys in interface RawStorepublic void verifySchema()
throws org.apache.hadoop.hive.metastore.api.MetaException
verifySchema in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic String getMetaStoreSchemaVersion() throws org.apache.hadoop.hive.metastore.api.MetaException
getMetaStoreSchemaVersion in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic void setMetaStoreSchemaVersion(String version, String comment) throws org.apache.hadoop.hive.metastore.api.MetaException
setMetaStoreSchemaVersion in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalDBGrantsAll(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
RawStorelistPrincipalDBGrantsAll in interface RawStoreprincipalName - principal nameprincipalType - typepublic List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalTableGrantsAll(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
RawStorelistPrincipalTableGrantsAll in interface RawStoreprincipalName - principal nameprincipalType - typepublic List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalPartitionGrantsAll(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
RawStorelistPrincipalPartitionGrantsAll in interface RawStoreprincipalName - principal nameprincipalType - typepublic List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalTableColumnGrantsAll(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
RawStorelistPrincipalTableColumnGrantsAll in interface RawStoreprincipalName - principal nameprincipalType - typepublic List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPrincipalPartitionColumnGrantsAll(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType)
RawStorelistPrincipalPartitionColumnGrantsAll in interface RawStoreprincipalName - principal nameprincipalType - typepublic List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listGlobalGrantsAll()
listGlobalGrantsAll in interface RawStorepublic List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listDBGrantsAll(String catName, String dbName)
RawStorelistDBGrantsAll in interface RawStorecatName - catalog namedbName - database namepublic List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPartitionColumnGrantsAll(String catName, String dbName, String tableName, String partitionName, String columnName)
RawStorelistPartitionColumnGrantsAll in interface RawStorecatName - catalog namedbName - database nametableName - table namepartitionName - partition name (not value)columnName - column namepublic List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listTableGrantsAll(String catName, String dbName, String tableName)
RawStorelistTableGrantsAll in interface RawStorecatName - catalog namedbName - database nametableName - table namepublic List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listPartitionGrantsAll(String catName, String dbName, String tableName, String partitionName)
RawStorelistPartitionGrantsAll in interface RawStorecatName - catalog namedbName - database nametableName - table namepartitionName - partition name (not value)public List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> listTableColumnGrantsAll(String catName, String dbName, String tableName, String columnName)
RawStorelistTableColumnGrantsAll in interface RawStorecatName - catalog namedbName - database nametableName - table namecolumnName - column namepublic void createFunction(org.apache.hadoop.hive.metastore.api.Function func)
throws org.apache.hadoop.hive.metastore.api.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
RawStorecreateFunction in interface RawStorefunc - function to createorg.apache.hadoop.hive.metastore.api.InvalidObjectException - incorrectly specified functionorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSpublic void 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
RawStorealterFunction in interface RawStoredbName - 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 functionpublic void 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
RawStoredropFunction in interface RawStoredbName - 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 thrownpublic org.apache.hadoop.hive.metastore.api.Function getFunction(String catName, String dbName, String funcName) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetFunction in interface RawStoredbName - database namefuncName - function nameorg.apache.hadoop.hive.metastore.api.MetaException - incorrectly specified functionpublic List<org.apache.hadoop.hive.metastore.api.Function> getAllFunctions(String catName) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetAllFunctions in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaException - incorrectly specified functionpublic List<String> getFunctions(String catName, String dbName, String pattern) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetFunctions in interface RawStoredbName - database namepattern - pattern to matchorg.apache.hadoop.hive.metastore.api.MetaException - incorrectly specified functionpublic org.apache.hadoop.hive.metastore.api.NotificationEventResponse getNextNotification(org.apache.hadoop.hive.metastore.api.NotificationEventRequest rqst)
RawStoregetNextNotification in interface RawStorerqst - Request containing information on the last processed notification.public void addNotificationEvent(org.apache.hadoop.hive.metastore.api.NotificationEvent event)
RawStoreaddNotificationEvent in interface RawStoreevent - the notification to addpublic void cleanNotificationEvents(int olderThan)
RawStorecleanNotificationEvents in interface RawStoreolderThan - Remove any events older than a given number of secondspublic org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId getCurrentNotificationEventId()
RawStoregetCurrentNotificationEventId in interface RawStorepublic org.apache.hadoop.hive.metastore.api.NotificationEventsCountResponse getNotificationEventsCount(org.apache.hadoop.hive.metastore.api.NotificationEventsCountRequest rqst)
RawStoregetNotificationEventsCount in interface RawStorepublic void flushCache()
flushCache in interface RawStorepublic ByteBuffer[] getFileMetadata(List<Long> fileIds) throws org.apache.hadoop.hive.metastore.api.MetaException
getFileMetadata in interface RawStorefileIds - List of file IDs from the filesystem.org.apache.hadoop.hive.metastore.api.MetaExceptionpublic void putFileMetadata(List<Long> fileIds, List<ByteBuffer> metadata, org.apache.hadoop.hive.metastore.api.FileMetadataExprType type) throws org.apache.hadoop.hive.metastore.api.MetaException
putFileMetadata in interface RawStorefileIds - 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.MetaExceptionpublic boolean isFileMetadataSupported()
isFileMetadataSupported in interface RawStorepublic 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
RawStoregetFileMetadataByExpr in interface RawStorefileIds - List of file IDs from the filesystem.type - Expression type; used to determine the class that handles the metadata.expr - Format-specific serialized expression applicable to the files' metadatas.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.MetaExceptionpublic FileMetadataHandler getFileMetadataHandler(org.apache.hadoop.hive.metastore.api.FileMetadataExprType type)
RawStoregetFileMetadataHandler in interface RawStorepublic int getTableCount()
throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetTableCount in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic int getPartitionCount()
throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetPartitionCount in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic int getDatabaseCount()
throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetDatabaseCount in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic List<org.apache.hadoop.hive.metastore.api.SQLPrimaryKey> getPrimaryKeys(String catName, String db_name, String tbl_name) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetPrimaryKeys in interface RawStorecatName - catalog namedb_name - database nametbl_name - table nameorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSpublic 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) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetForeignKeys in interface RawStorecatName - 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.public 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
RawStoregetUniqueConstraints in interface RawStorecatName - catalog name.db_name - database name.tbl_name - table name.org.apache.hadoop.hive.metastore.api.MetaException - error access the RDBMS.public 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
RawStoregetNotNullConstraints in interface RawStorecatName - catalog name.db_name - database name.tbl_name - table name.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.public 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
RawStoregetDefaultConstraints in interface RawStorecatName - catalog namedb_name - database nametbl_name - table nameorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSpublic List<org.apache.hadoop.hive.metastore.api.SQLCheckConstraint> getCheckConstraints(String catName, String db_name, String tbl_name) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetCheckConstraints in interface RawStorecatName - catalog name.db_name - database nametbl_name - table nameorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSpublic 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) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
RawStorecreateTableWithConstraints in interface RawStoretbl - 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 RDBMSpublic void dropConstraint(String catName, String dbName, String tableName, String constraintName, boolean missingOk) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException
RawStoredropConstraint in interface RawStorecatName - 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 = falsepublic List<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
RawStoreaddPrimaryKeys in interface RawStorepks - 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 RDMBSpublic List<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
RawStoreaddForeignKeys in interface RawStorefks - foreign key specificationorg.apache.hadoop.hive.metastore.api.InvalidObjectException - the specification is malformed.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.public 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
RawStoreaddUniqueConstraints in interface RawStoreuks - unique constraints specificationorg.apache.hadoop.hive.metastore.api.InvalidObjectException - the specification is malformed.org.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMS.public 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
RawStoreaddNotNullConstraints in interface RawStorenns - 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.public List<String> addDefaultConstraints(List<org.apache.hadoop.hive.metastore.api.SQLDefaultConstraint> nns) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
RawStoreaddDefaultConstraints in interface RawStorenns - 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.public List<String> addCheckConstraints(List<org.apache.hadoop.hive.metastore.api.SQLCheckConstraint> nns) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
RawStoreaddCheckConstraints in interface RawStorenns - check constraints to addorg.apache.hadoop.hive.metastore.api.InvalidObjectException - the specification is malformedorg.apache.hadoop.hive.metastore.api.MetaException - error accessing the RDBMSpublic void createISchema(org.apache.hadoop.hive.metastore.api.ISchema schema)
throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
RawStorecreateISchema in interface RawStoreschema - 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.NoSuchObjectExceptionpublic List<MetaStoreUtils.ColStatsObjWithSourceInfo> getPartitionColStatsForDatabase(String catName, String dbName) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
RawStoregetPartitionColStatsForDatabase in interface RawStorecatName - catalog namedbName - database nameorg.apache.hadoop.hive.metastore.api.MetaException - error accessing RDBMSorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no such databasepublic void 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
RawStorealterISchema in interface RawStoreschemaName - 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 exceptionpublic org.apache.hadoop.hive.metastore.api.ISchema getISchema(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName)
throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetISchema in interface RawStoreschemaName - schema descriptororg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionpublic void dropISchema(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName)
throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
RawStoredropISchema in interface RawStoreschemaName - schema descriptororg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no schema of this name existsorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionpublic void 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
RawStoreaddSchemaVersion in interface RawStoreschemaVersion - 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 exceptionpublic void 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
RawStorealterSchemaVersion in interface RawStoreversion - 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 exceptionpublic org.apache.hadoop.hive.metastore.api.SchemaVersion getSchemaVersion(org.apache.hadoop.hive.metastore.api.SchemaVersionDescriptor version)
throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetSchemaVersion in interface RawStoreversion - version descriptor for the schemaorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionpublic org.apache.hadoop.hive.metastore.api.SchemaVersion getLatestSchemaVersion(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName)
throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetLatestSchemaVersion in interface RawStoreschemaName - name of the schemaorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionpublic List<org.apache.hadoop.hive.metastore.api.SchemaVersion> getAllSchemaVersion(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetAllSchemaVersion in interface RawStoreschemaName - name of the schemaorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionpublic List<org.apache.hadoop.hive.metastore.api.SchemaVersion> getSchemaVersionsByColumns(String colName, String colNamespace, String type) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetSchemaVersionsByColumns in interface RawStorecolName - 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 exceptionpublic void dropSchemaVersion(org.apache.hadoop.hive.metastore.api.SchemaVersionDescriptor version)
throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.MetaException
RawStoredropSchemaVersion in interface RawStoreversion - 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 exceptionpublic org.apache.hadoop.hive.metastore.api.SerDeInfo getSerDeInfo(String serDeName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetSerDeInfo in interface RawStoreserDeName - name of the SerDeorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - no serde with this name existsorg.apache.hadoop.hive.metastore.api.MetaException - general database exceptionpublic void addSerde(org.apache.hadoop.hive.metastore.api.SerDeInfo serde)
throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException,
org.apache.hadoop.hive.metastore.api.MetaException
RawStorepublic RawStore getRawStore()
public void setRawStore(RawStore rawStore)
public String getMetastoreDbUuid() throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetMetastoreDbUuid in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic void 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.InvalidObjectException,
org.apache.hadoop.hive.metastore.api.MetaException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
createResourcePlan in interface RawStoreorg.apache.hadoop.hive.metastore.api.AlreadyExistsExceptionorg.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionpublic org.apache.hadoop.hive.metastore.api.WMFullResourcePlan getResourcePlan(String name) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
getResourcePlan in interface RawStoreorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic List<org.apache.hadoop.hive.metastore.api.WMResourcePlan> getAllResourcePlans() throws org.apache.hadoop.hive.metastore.api.MetaException
getAllResourcePlans in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic org.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
alterResourcePlan in interface RawStoreorg.apache.hadoop.hive.metastore.api.AlreadyExistsExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic org.apache.hadoop.hive.metastore.api.WMFullResourcePlan getActiveResourcePlan()
throws org.apache.hadoop.hive.metastore.api.MetaException
getActiveResourcePlan in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic org.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
validateResourcePlan in interface RawStoreorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic void dropResourcePlan(String name) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
dropResourcePlan in interface RawStoreorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic void createWMTrigger(org.apache.hadoop.hive.metastore.api.WMTrigger trigger)
throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException,
org.apache.hadoop.hive.metastore.api.MetaException,
org.apache.hadoop.hive.metastore.api.NoSuchObjectException,
org.apache.hadoop.hive.metastore.api.InvalidOperationException
createWMTrigger in interface RawStoreorg.apache.hadoop.hive.metastore.api.AlreadyExistsExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionpublic void 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
alterWMTrigger in interface RawStoreorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic void 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
dropWMTrigger in interface RawStoreorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic List<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
getTriggersForResourcePlan in interface RawStoreorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic void 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
createPool in interface RawStoreorg.apache.hadoop.hive.metastore.api.AlreadyExistsExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic void 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
public void 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
dropWMPool in interface RawStoreorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic void 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
createOrUpdateWMMapping in interface RawStoreorg.apache.hadoop.hive.metastore.api.AlreadyExistsExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic void 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
dropWMMapping in interface RawStoreorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic void 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
createWMTriggerToPoolMapping in interface RawStoreorg.apache.hadoop.hive.metastore.api.AlreadyExistsExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic void 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
dropWMTriggerToPoolMapping in interface RawStoreorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionorg.apache.hadoop.hive.metastore.api.InvalidOperationExceptionorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic long getCacheUpdateCount()
public void addRuntimeStat(org.apache.hadoop.hive.metastore.api.RuntimeStat stat)
throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoreaddRuntimeStat in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic List<org.apache.hadoop.hive.metastore.api.RuntimeStat> getRuntimeStats(int maxEntries, int maxCreateTime) throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoregetRuntimeStats in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic int deleteRuntimeStats(int maxRetainSecs)
throws org.apache.hadoop.hive.metastore.api.MetaException
RawStoredeleteRuntimeStats in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionpublic List<MetaStoreUtils.FullTableName> getTableNamesWithStats() throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
getTableNamesWithStats in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionpublic List<MetaStoreUtils.FullTableName> getAllTableNamesForStats() throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
getAllTableNamesForStats in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionpublic Map<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
getPartitionColsWithStats in interface RawStoreorg.apache.hadoop.hive.metastore.api.MetaExceptionorg.apache.hadoop.hive.metastore.api.NoSuchObjectExceptionCopyright © 2019 The Apache Software Foundation. All Rights Reserved.