Package | Description |
---|---|
org.apache.hadoop.hive.metastore | |
org.apache.hadoop.hive.metastore.api | |
org.apache.hadoop.hive.ql.metadata |
Modifier and Type | Method and Description |
---|---|
List<FieldSchema> |
HiveMetaStore.HMSHandler.get_fields_with_environment_context(String db,
String tableName,
EnvironmentContext envContext) |
List<FieldSchema> |
HiveMetaStore.HMSHandler.get_fields(String db,
String tableName) |
List<FieldSchema> |
HiveMetaStore.HMSHandler.get_schema_with_environment_context(String db,
String tableName,
EnvironmentContext envContext)
Return the schema of the table.
|
List<FieldSchema> |
HiveMetaStore.HMSHandler.get_schema(String db,
String tableName)
Return the schema of the table.
|
List<String> |
HiveMetaStore.HMSHandler.get_table_names_by_filter(String dbName,
String filter,
short maxTables) |
List<Table> |
HiveMetaStore.HMSHandler.get_table_objects_by_name(String dbname,
List<String> names)
Gets multiple tables from the hive metastore.
|
List<String> |
IMetaStoreClient.getAllTables(String dbName)
Get the names of all tables in the specified database.
|
List<FieldSchema> |
IMetaStoreClient.getFields(String db,
String tableName) |
List<FieldSchema> |
HiveMetaStoreClient.getFields(String db,
String tableName) |
List<FieldSchema> |
IMetaStoreClient.getSchema(String db,
String tableName) |
List<FieldSchema> |
HiveMetaStoreClient.getSchema(String db,
String tableName) |
List<Table> |
RawStore.getTableObjectsByName(String dbname,
List<String> tableNames) |
List<Table> |
ObjectStore.getTableObjectsByName(String db,
List<String> tbl_names) |
List<Table> |
IMetaStoreClient.getTableObjectsByName(String dbName,
List<String> tableNames) |
List<Table> |
HiveMetaStoreClient.getTableObjectsByName(String dbName,
List<String> tableNames) |
List<String> |
IMetaStoreClient.getTables(String dbName,
String tablePattern)
Get the names of all tables in the specified database that satisfy the supplied
table name pattern.
|
boolean |
IMetaStoreClient.isPartitionMarkedForEvent(String db_name,
String tbl_name,
Map<String,String> partKVs,
PartitionEventType eventType) |
boolean |
HiveMetaStoreClient.isPartitionMarkedForEvent(String db_name,
String tbl_name,
Map<String,String> partKVs,
PartitionEventType eventType) |
boolean |
HiveMetaStore.HMSHandler.isPartitionMarkedForEvent(String db_name,
String tbl_name,
Map<String,String> partName,
PartitionEventType evtType) |
List<String> |
RawStore.listTableNamesByFilter(String dbName,
String filter,
short max_tables)
Gets a list of tables based on a filter string and filter type.
|
List<String> |
IMetaStoreClient.listTableNamesByFilter(String dbName,
String filter,
short maxTables)
Get a list of table names that match a filter.
|
List<String> |
HiveMetaStoreClient.listTableNamesByFilter(String dbName,
String filter,
short maxTables)
Get a list of table names that match a filter.
|
void |
IMetaStoreClient.markPartitionForEvent(String db_name,
String tbl_name,
Map<String,String> partKVs,
PartitionEventType eventType) |
void |
HiveMetaStoreClient.markPartitionForEvent(String db_name,
String tbl_name,
Map<String,String> partKVs,
PartitionEventType eventType) |
void |
HiveMetaStore.HMSHandler.markPartitionForEvent(String db_name,
String tbl_name,
Map<String,String> partName,
PartitionEventType evtType) |
boolean |
IMetaStoreClient.tableExists(String tableName)
Deprecated.
As of release 0.6.0 replaced by
IMetaStoreClient.tableExists(String, String) .
This method will be removed in release 0.7.0. |
boolean |
HiveMetaStoreClient.tableExists(String tableName)
Deprecated.
|
boolean |
IMetaStoreClient.tableExists(String databaseName,
String tableName) |
boolean |
HiveMetaStoreClient.tableExists(String databaseName,
String tableName) |
Modifier and Type | Method and Description |
---|---|
UnknownDBException |
UnknownDBException.deepCopy() |
UnknownDBException |
ThriftHiveMetastore.get_fields_result.getO3() |
UnknownDBException |
ThriftHiveMetastore.get_fields_with_environment_context_result.getO3() |
UnknownDBException |
ThriftHiveMetastore.get_schema_result.getO3() |
UnknownDBException |
ThriftHiveMetastore.get_schema_with_environment_context_result.getO3() |
UnknownDBException |
ThriftHiveMetastore.get_table_objects_by_name_result.getO3() |
UnknownDBException |
ThriftHiveMetastore.get_table_names_by_filter_result.getO3() |
UnknownDBException |
ThriftHiveMetastore.markPartitionForEvent_result.getO3() |
UnknownDBException |
ThriftHiveMetastore.isPartitionMarkedForEvent_result.getO3() |
Modifier and Type | Method and Description |
---|---|
int |
UnknownDBException.compareTo(UnknownDBException other) |
boolean |
UnknownDBException.equals(UnknownDBException that) |
void |
ThriftHiveMetastore.get_fields_result.setO3(UnknownDBException o3) |
void |
ThriftHiveMetastore.get_fields_with_environment_context_result.setO3(UnknownDBException o3) |
void |
ThriftHiveMetastore.get_schema_result.setO3(UnknownDBException o3) |
void |
ThriftHiveMetastore.get_schema_with_environment_context_result.setO3(UnknownDBException o3) |
void |
ThriftHiveMetastore.get_table_objects_by_name_result.setO3(UnknownDBException o3) |
void |
ThriftHiveMetastore.get_table_names_by_filter_result.setO3(UnknownDBException o3) |
void |
ThriftHiveMetastore.markPartitionForEvent_result.setO3(UnknownDBException o3) |
void |
ThriftHiveMetastore.isPartitionMarkedForEvent_result.setO3(UnknownDBException o3) |
Modifier and Type | Method and Description |
---|---|
List<FieldSchema> |
ThriftHiveMetastore.Iface.get_fields_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context) |
List<FieldSchema> |
ThriftHiveMetastore.Client.get_fields_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context) |
List<FieldSchema> |
ThriftHiveMetastore.Iface.get_fields(String db_name,
String table_name) |
List<FieldSchema> |
ThriftHiveMetastore.Client.get_fields(String db_name,
String table_name) |
List<FieldSchema> |
ThriftHiveMetastore.Iface.get_schema_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context) |
List<FieldSchema> |
ThriftHiveMetastore.Client.get_schema_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context) |
List<FieldSchema> |
ThriftHiveMetastore.Iface.get_schema(String db_name,
String table_name) |
List<FieldSchema> |
ThriftHiveMetastore.Client.get_schema(String db_name,
String table_name) |
List<String> |
ThriftHiveMetastore.Iface.get_table_names_by_filter(String dbname,
String filter,
short max_tables) |
List<String> |
ThriftHiveMetastore.Client.get_table_names_by_filter(String dbname,
String filter,
short max_tables) |
List<Table> |
ThriftHiveMetastore.Iface.get_table_objects_by_name(String dbname,
List<String> tbl_names) |
List<Table> |
ThriftHiveMetastore.Client.get_table_objects_by_name(String dbname,
List<String> tbl_names) |
List<FieldSchema> |
ThriftHiveMetastore.AsyncClient.get_fields_call.getResult() |
List<FieldSchema> |
ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call.getResult() |
List<FieldSchema> |
ThriftHiveMetastore.AsyncClient.get_schema_call.getResult() |
List<FieldSchema> |
ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call.getResult() |
List<Table> |
ThriftHiveMetastore.AsyncClient.get_table_objects_by_name_call.getResult() |
List<String> |
ThriftHiveMetastore.AsyncClient.get_table_names_by_filter_call.getResult() |
void |
ThriftHiveMetastore.AsyncClient.markPartitionForEvent_call.getResult() |
boolean |
ThriftHiveMetastore.AsyncClient.isPartitionMarkedForEvent_call.getResult() |
boolean |
ThriftHiveMetastore.Iface.isPartitionMarkedForEvent(String db_name,
String tbl_name,
Map<String,String> part_vals,
PartitionEventType eventType) |
boolean |
ThriftHiveMetastore.Client.isPartitionMarkedForEvent(String db_name,
String tbl_name,
Map<String,String> part_vals,
PartitionEventType eventType) |
void |
ThriftHiveMetastore.Iface.markPartitionForEvent(String db_name,
String tbl_name,
Map<String,String> part_vals,
PartitionEventType eventType) |
void |
ThriftHiveMetastore.Client.markPartitionForEvent(String db_name,
String tbl_name,
Map<String,String> part_vals,
PartitionEventType eventType) |
List<FieldSchema> |
ThriftHiveMetastore.Client.recv_get_fields_with_environment_context() |
List<FieldSchema> |
ThriftHiveMetastore.Client.recv_get_fields() |
List<FieldSchema> |
ThriftHiveMetastore.Client.recv_get_schema_with_environment_context() |
List<FieldSchema> |
ThriftHiveMetastore.Client.recv_get_schema() |
List<String> |
ThriftHiveMetastore.Client.recv_get_table_names_by_filter() |
List<Table> |
ThriftHiveMetastore.Client.recv_get_table_objects_by_name() |
boolean |
ThriftHiveMetastore.Client.recv_isPartitionMarkedForEvent() |
void |
ThriftHiveMetastore.Client.recv_markPartitionForEvent() |
Modifier and Type | Method and Description |
---|---|
List<FieldSchema> |
SessionHiveMetaStoreClient.getSchema(String dbName,
String tableName) |
List<Table> |
SessionHiveMetaStoreClient.getTableObjectsByName(String dbName,
List<String> tableNames) |
boolean |
SessionHiveMetaStoreClient.tableExists(String databaseName,
String tableName) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.