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 |
---|---|
Index |
HiveMetaStore.HMSHandler.add_index(Index newIndex,
Table indexTable) |
Partition |
HiveMetaStore.HMSHandler.add_partition_with_environment_context(Partition part,
EnvironmentContext envContext) |
Partition |
IMetaStoreClient.add_partition(Partition partition)
Add a partition to the table.
|
Partition |
HiveMetaStoreClient.add_partition(Partition new_part) |
Partition |
HiveMetaStore.HMSHandler.add_partition(Partition part) |
Partition |
HiveMetaStoreClient.add_partition(Partition new_part,
EnvironmentContext envContext) |
int |
IMetaStoreClient.add_partitions_pspec(PartitionSpecProxy partitionSpec) |
AddPartitionsResult |
HiveMetaStore.HMSHandler.add_partitions_req(AddPartitionsRequest request) |
int |
IMetaStoreClient.add_partitions(List<Partition> partitions)
Add partitions to the table.
|
int |
HiveMetaStoreClient.add_partitions(List<Partition> new_parts) |
int |
HiveMetaStore.HMSHandler.add_partitions(List<Partition> parts) |
List<Partition> |
IMetaStoreClient.add_partitions(List<Partition> partitions,
boolean ifNotExists,
boolean needResults)
Add partitions to the table.
|
List<Partition> |
HiveMetaStoreClient.add_partitions(List<Partition> parts,
boolean ifNotExists,
boolean needResults) |
Partition |
HiveAlterHandler.alterPartition(RawStore msdb,
Warehouse wh,
String dbname,
String name,
List<String> part_vals,
Partition new_part) |
Partition |
AlterHandler.alterPartition(RawStore msdb,
Warehouse wh,
String dbname,
String name,
List<String> part_vals,
Partition new_part)
handles alter partition
|
List<Partition> |
HiveAlterHandler.alterPartitions(RawStore msdb,
Warehouse wh,
String dbname,
String name,
List<Partition> new_parts) |
List<Partition> |
AlterHandler.alterPartitions(RawStore msdb,
Warehouse wh,
String dbname,
String name,
List<Partition> new_part)
handles alter partitions
|
Partition |
HiveMetaStore.HMSHandler.append_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
EnvironmentContext env_context) |
Partition |
HiveMetaStore.HMSHandler.append_partition_by_name(String db_name,
String tbl_name,
String part_name) |
Partition |
HiveMetaStore.HMSHandler.append_partition_with_environment_context(String dbName,
String tableName,
List<String> part_vals,
EnvironmentContext envContext) |
Partition |
HiveMetaStore.HMSHandler.append_partition(String dbName,
String tableName,
List<String> part_vals) |
Partition |
IMetaStoreClient.appendPartition(String tableName,
String dbName,
List<String> partVals) |
Partition |
HiveMetaStoreClient.appendPartition(String db_name,
String table_name,
List<String> part_vals) |
Partition |
HiveMetaStoreClient.appendPartition(String db_name,
String table_name,
List<String> part_vals,
EnvironmentContext envContext) |
Partition |
IMetaStoreClient.appendPartition(String tableName,
String dbName,
String name) |
Partition |
HiveMetaStoreClient.appendPartition(String dbName,
String tableName,
String partName) |
Partition |
HiveMetaStoreClient.appendPartition(String dbName,
String tableName,
String partName,
EnvironmentContext envContext) |
Partition |
HiveMetaStoreClient.appendPartitionByName(String dbName,
String tableName,
String partName) |
Partition |
HiveMetaStoreClient.appendPartitionByName(String dbName,
String tableName,
String partName,
EnvironmentContext envContext) |
void |
HiveMetaStore.HMSHandler.create_database(Database db) |
void |
HiveMetaStore.HMSHandler.create_function(Function func) |
protected void |
HiveMetaStoreClient.create_table_with_environment_context(Table tbl,
EnvironmentContext envContext) |
void |
HiveMetaStore.HMSHandler.create_table_with_environment_context(Table tbl,
EnvironmentContext envContext) |
void |
HiveMetaStore.HMSHandler.create_table(Table tbl) |
boolean |
HiveMetaStore.HMSHandler.create_type(Type type) |
void |
IMetaStoreClient.createDatabase(Database db) |
void |
HiveMetaStoreClient.createDatabase(Database db)
Create a new Database
|
void |
IMetaStoreClient.createIndex(Index index,
Table indexTable)
create an index
|
void |
HiveMetaStoreClient.createIndex(Index index,
Table indexTable)
create an index
|
void |
IMetaStoreClient.createTable(Table tbl) |
void |
HiveMetaStoreClient.createTable(Table tbl) |
void |
HiveMetaStoreClient.createTable(Table tbl,
EnvironmentContext envContext) |
boolean |
HiveMetaStoreClient.createType(Type type) |
Modifier and Type | Method and Description |
---|---|
AlreadyExistsException |
AlreadyExistsException.deepCopy() |
AlreadyExistsException |
ThriftHiveMetastore.create_database_result.getO1() |
AlreadyExistsException |
ThriftHiveMetastore.create_type_result.getO1() |
AlreadyExistsException |
ThriftHiveMetastore.create_table_result.getO1() |
AlreadyExistsException |
ThriftHiveMetastore.create_table_with_environment_context_result.getO1() |
AlreadyExistsException |
ThriftHiveMetastore.create_function_result.getO1() |
AlreadyExistsException |
ThriftHiveMetastore.add_partition_result.getO2() |
AlreadyExistsException |
ThriftHiveMetastore.add_partition_with_environment_context_result.getO2() |
AlreadyExistsException |
ThriftHiveMetastore.add_partitions_result.getO2() |
AlreadyExistsException |
ThriftHiveMetastore.add_partitions_pspec_result.getO2() |
AlreadyExistsException |
ThriftHiveMetastore.append_partition_result.getO2() |
AlreadyExistsException |
ThriftHiveMetastore.add_partitions_req_result.getO2() |
AlreadyExistsException |
ThriftHiveMetastore.append_partition_with_environment_context_result.getO2() |
AlreadyExistsException |
ThriftHiveMetastore.append_partition_by_name_result.getO2() |
AlreadyExistsException |
ThriftHiveMetastore.append_partition_by_name_with_environment_context_result.getO2() |
AlreadyExistsException |
ThriftHiveMetastore.add_index_result.getO2() |
Modifier and Type | Method and Description |
---|---|
int |
AlreadyExistsException.compareTo(AlreadyExistsException other) |
boolean |
AlreadyExistsException.equals(AlreadyExistsException that) |
void |
ThriftHiveMetastore.create_database_result.setO1(AlreadyExistsException o1) |
void |
ThriftHiveMetastore.create_type_result.setO1(AlreadyExistsException o1) |
void |
ThriftHiveMetastore.create_table_result.setO1(AlreadyExistsException o1) |
void |
ThriftHiveMetastore.create_table_with_environment_context_result.setO1(AlreadyExistsException o1) |
void |
ThriftHiveMetastore.create_function_result.setO1(AlreadyExistsException o1) |
void |
ThriftHiveMetastore.add_partition_result.setO2(AlreadyExistsException o2) |
void |
ThriftHiveMetastore.add_partition_with_environment_context_result.setO2(AlreadyExistsException o2) |
void |
ThriftHiveMetastore.add_partitions_result.setO2(AlreadyExistsException o2) |
void |
ThriftHiveMetastore.add_partitions_pspec_result.setO2(AlreadyExistsException o2) |
void |
ThriftHiveMetastore.append_partition_result.setO2(AlreadyExistsException o2) |
void |
ThriftHiveMetastore.add_partitions_req_result.setO2(AlreadyExistsException o2) |
void |
ThriftHiveMetastore.append_partition_with_environment_context_result.setO2(AlreadyExistsException o2) |
void |
ThriftHiveMetastore.append_partition_by_name_result.setO2(AlreadyExistsException o2) |
void |
ThriftHiveMetastore.append_partition_by_name_with_environment_context_result.setO2(AlreadyExistsException o2) |
void |
ThriftHiveMetastore.add_index_result.setO2(AlreadyExistsException o2) |
Modifier and Type | Method and Description |
---|---|
Index |
ThriftHiveMetastore.Iface.add_index(Index new_index,
Table index_table) |
Index |
ThriftHiveMetastore.Client.add_index(Index new_index,
Table index_table) |
Partition |
ThriftHiveMetastore.Iface.add_partition_with_environment_context(Partition new_part,
EnvironmentContext environment_context) |
Partition |
ThriftHiveMetastore.Client.add_partition_with_environment_context(Partition new_part,
EnvironmentContext environment_context) |
Partition |
ThriftHiveMetastore.Iface.add_partition(Partition new_part) |
Partition |
ThriftHiveMetastore.Client.add_partition(Partition new_part) |
int |
ThriftHiveMetastore.Iface.add_partitions_pspec(List<PartitionSpec> new_parts) |
int |
ThriftHiveMetastore.Client.add_partitions_pspec(List<PartitionSpec> new_parts) |
AddPartitionsResult |
ThriftHiveMetastore.Iface.add_partitions_req(AddPartitionsRequest request) |
AddPartitionsResult |
ThriftHiveMetastore.Client.add_partitions_req(AddPartitionsRequest request) |
int |
ThriftHiveMetastore.Iface.add_partitions(List<Partition> new_parts) |
int |
ThriftHiveMetastore.Client.add_partitions(List<Partition> new_parts) |
Partition |
ThriftHiveMetastore.Iface.append_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
EnvironmentContext environment_context) |
Partition |
ThriftHiveMetastore.Client.append_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
EnvironmentContext environment_context) |
Partition |
ThriftHiveMetastore.Iface.append_partition_by_name(String db_name,
String tbl_name,
String part_name) |
Partition |
ThriftHiveMetastore.Client.append_partition_by_name(String db_name,
String tbl_name,
String part_name) |
Partition |
ThriftHiveMetastore.Iface.append_partition_with_environment_context(String db_name,
String tbl_name,
List<String> part_vals,
EnvironmentContext environment_context) |
Partition |
ThriftHiveMetastore.Client.append_partition_with_environment_context(String db_name,
String tbl_name,
List<String> part_vals,
EnvironmentContext environment_context) |
Partition |
ThriftHiveMetastore.Iface.append_partition(String db_name,
String tbl_name,
List<String> part_vals) |
Partition |
ThriftHiveMetastore.Client.append_partition(String db_name,
String tbl_name,
List<String> part_vals) |
void |
ThriftHiveMetastore.Iface.create_database(Database database) |
void |
ThriftHiveMetastore.Client.create_database(Database database) |
void |
ThriftHiveMetastore.Iface.create_function(Function func) |
void |
ThriftHiveMetastore.Client.create_function(Function func) |
void |
ThriftHiveMetastore.Iface.create_table_with_environment_context(Table tbl,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.create_table_with_environment_context(Table tbl,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Iface.create_table(Table tbl) |
void |
ThriftHiveMetastore.Client.create_table(Table tbl) |
boolean |
ThriftHiveMetastore.Iface.create_type(Type type) |
boolean |
ThriftHiveMetastore.Client.create_type(Type type) |
void |
ThriftHiveMetastore.AsyncClient.create_database_call.getResult() |
boolean |
ThriftHiveMetastore.AsyncClient.create_type_call.getResult() |
void |
ThriftHiveMetastore.AsyncClient.create_table_call.getResult() |
void |
ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call.getResult() |
Partition |
ThriftHiveMetastore.AsyncClient.add_partition_call.getResult() |
Partition |
ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call.getResult() |
int |
ThriftHiveMetastore.AsyncClient.add_partitions_call.getResult() |
int |
ThriftHiveMetastore.AsyncClient.add_partitions_pspec_call.getResult() |
Partition |
ThriftHiveMetastore.AsyncClient.append_partition_call.getResult() |
AddPartitionsResult |
ThriftHiveMetastore.AsyncClient.add_partitions_req_call.getResult() |
Partition |
ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context_call.getResult() |
Partition |
ThriftHiveMetastore.AsyncClient.append_partition_by_name_call.getResult() |
Partition |
ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context_call.getResult() |
Index |
ThriftHiveMetastore.AsyncClient.add_index_call.getResult() |
void |
ThriftHiveMetastore.AsyncClient.create_function_call.getResult() |
Index |
ThriftHiveMetastore.Client.recv_add_index() |
Partition |
ThriftHiveMetastore.Client.recv_add_partition_with_environment_context() |
Partition |
ThriftHiveMetastore.Client.recv_add_partition() |
int |
ThriftHiveMetastore.Client.recv_add_partitions_pspec() |
AddPartitionsResult |
ThriftHiveMetastore.Client.recv_add_partitions_req() |
int |
ThriftHiveMetastore.Client.recv_add_partitions() |
Partition |
ThriftHiveMetastore.Client.recv_append_partition_by_name_with_environment_context() |
Partition |
ThriftHiveMetastore.Client.recv_append_partition_by_name() |
Partition |
ThriftHiveMetastore.Client.recv_append_partition_with_environment_context() |
Partition |
ThriftHiveMetastore.Client.recv_append_partition() |
void |
ThriftHiveMetastore.Client.recv_create_database() |
void |
ThriftHiveMetastore.Client.recv_create_function() |
void |
ThriftHiveMetastore.Client.recv_create_table_with_environment_context() |
void |
ThriftHiveMetastore.Client.recv_create_table() |
boolean |
ThriftHiveMetastore.Client.recv_create_type() |
Modifier and Type | Method and Description |
---|---|
protected void |
SessionHiveMetaStoreClient.create_table_with_environment_context(Table tbl,
EnvironmentContext envContext) |
void |
Hive.createDatabase(Database db)
Create a Database.
|
void |
Hive.createDatabase(Database db,
boolean ifNotExist)
Create a database
|
Copyright © 2017 The Apache Software Foundation. All rights reserved.