Package | Description |
---|---|
org.apache.hadoop.hive.metastore | |
org.apache.hadoop.hive.metastore.api | |
org.apache.hadoop.hive.metastore.events | |
org.apache.hadoop.hive.ql.metadata |
Modifier and Type | Method and Description |
---|---|
Partition |
HiveMetaStore.HMSHandler.add_partition_with_environment_context(Partition part,
EnvironmentContext envContext) |
Partition |
HiveMetaStoreClient.add_partition(Partition new_part,
EnvironmentContext envContext) |
void |
HiveMetaStore.HMSHandler.alter_partition_with_environment_context(String dbName,
String tableName,
Partition newPartition,
EnvironmentContext envContext) |
void |
HiveMetaStore.HMSHandler.alter_table_with_environment_context(String dbname,
String name,
Table newTable,
EnvironmentContext envContext) |
void |
HiveMetaStoreClient.alter_table(String dbname,
String tbl_name,
Table new_tbl,
EnvironmentContext envContext) |
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_with_environment_context(String dbName,
String tableName,
List<String> part_vals,
EnvironmentContext envContext) |
Partition |
HiveMetaStoreClient.appendPartition(String db_name,
String table_name,
List<String> part_vals,
EnvironmentContext envContext) |
Partition |
HiveMetaStoreClient.appendPartition(String dbName,
String tableName,
String partName,
EnvironmentContext envContext) |
Partition |
HiveMetaStoreClient.appendPartitionByName(String dbName,
String tableName,
String partName,
EnvironmentContext envContext) |
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 |
HiveMetaStoreClient.createTable(Table tbl,
EnvironmentContext envContext) |
boolean |
HiveMetaStore.HMSHandler.drop_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
boolean deleteData,
EnvironmentContext envContext) |
boolean |
HiveMetaStore.HMSHandler.drop_partition_with_environment_context(String db_name,
String tbl_name,
List<String> part_vals,
boolean deleteData,
EnvironmentContext envContext) |
protected void |
HiveMetaStoreClient.drop_table_with_environment_context(String dbname,
String name,
boolean deleteData,
EnvironmentContext envContext) |
void |
HiveMetaStore.HMSHandler.drop_table_with_environment_context(String dbname,
String name,
boolean deleteData,
EnvironmentContext envContext) |
boolean |
HiveMetaStoreClient.dropPartition(String db_name,
String tbl_name,
List<String> part_vals,
boolean deleteData,
EnvironmentContext envContext) |
boolean |
HiveMetaStoreClient.dropPartition(String db_name,
String tbl_name,
List<String> part_vals,
EnvironmentContext env_context) |
boolean |
HiveMetaStoreClient.dropPartition(String dbName,
String tableName,
String partName,
boolean deleteData,
EnvironmentContext envContext) |
boolean |
HiveMetaStoreClient.dropPartitionByName(String dbName,
String tableName,
String partName,
boolean deleteData,
EnvironmentContext envContext) |
void |
HiveMetaStoreClient.dropTable(String dbname,
String name,
boolean deleteData,
boolean ignoreUnknownTab,
EnvironmentContext envContext)
Drop the table and choose whether to: delete the underlying table data;
throw if the table doesn't exist; save the data in the trash.
|
List<FieldSchema> |
HiveMetaStore.HMSHandler.get_fields_with_environment_context(String db,
String tableName,
EnvironmentContext envContext) |
List<FieldSchema> |
HiveMetaStore.HMSHandler.get_schema_with_environment_context(String db,
String tableName,
EnvironmentContext envContext)
Return the schema of the table.
|
Modifier and Type | Method and Description |
---|---|
EnvironmentContext |
EnvironmentContext.deepCopy() |
EnvironmentContext |
ThriftHiveMetastore.get_fields_with_environment_context_args.getEnvironment_context() |
EnvironmentContext |
ThriftHiveMetastore.get_schema_with_environment_context_args.getEnvironment_context() |
EnvironmentContext |
ThriftHiveMetastore.create_table_with_environment_context_args.getEnvironment_context() |
EnvironmentContext |
ThriftHiveMetastore.drop_table_with_environment_context_args.getEnvironment_context() |
EnvironmentContext |
ThriftHiveMetastore.alter_table_with_environment_context_args.getEnvironment_context() |
EnvironmentContext |
ThriftHiveMetastore.add_partition_with_environment_context_args.getEnvironment_context() |
EnvironmentContext |
ThriftHiveMetastore.append_partition_with_environment_context_args.getEnvironment_context() |
EnvironmentContext |
ThriftHiveMetastore.append_partition_by_name_with_environment_context_args.getEnvironment_context() |
EnvironmentContext |
ThriftHiveMetastore.drop_partition_with_environment_context_args.getEnvironment_context() |
EnvironmentContext |
ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args.getEnvironment_context() |
EnvironmentContext |
ThriftHiveMetastore.alter_partition_with_environment_context_args.getEnvironment_context() |
EnvironmentContext |
DropPartitionsRequest.getEnvironmentContext() |
Modifier and Type | Method and Description |
---|---|
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) |
void |
ThriftHiveMetastore.AsyncIface.add_partition_with_environment_context(Partition new_part,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context(Partition new_part,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.Iface.alter_partition_with_environment_context(String db_name,
String tbl_name,
Partition new_part,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.alter_partition_with_environment_context(String db_name,
String tbl_name,
Partition new_part,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.AsyncIface.alter_partition_with_environment_context(String db_name,
String tbl_name,
Partition new_part,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context(String db_name,
String tbl_name,
Partition new_part,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.Iface.alter_table_with_environment_context(String dbname,
String tbl_name,
Table new_tbl,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.alter_table_with_environment_context(String dbname,
String tbl_name,
Table new_tbl,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.AsyncIface.alter_table_with_environment_context(String dbname,
String tbl_name,
Table new_tbl,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context(String dbname,
String tbl_name,
Table new_tbl,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context_call> resultHandler) |
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) |
void |
ThriftHiveMetastore.AsyncIface.append_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context_call> resultHandler) |
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) |
void |
ThriftHiveMetastore.AsyncIface.append_partition_with_environment_context(String db_name,
String tbl_name,
List<String> part_vals,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context(String db_name,
String tbl_name,
List<String> part_vals,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context_call> resultHandler) |
int |
EnvironmentContext.compareTo(EnvironmentContext other) |
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.AsyncIface.create_table_with_environment_context(Table tbl,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.create_table_with_environment_context(Table tbl,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call> resultHandler) |
boolean |
ThriftHiveMetastore.Iface.drop_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
boolean deleteData,
EnvironmentContext environment_context) |
boolean |
ThriftHiveMetastore.Client.drop_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
boolean deleteData,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.AsyncIface.drop_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
boolean deleteData,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_by_name_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.drop_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
boolean deleteData,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_by_name_with_environment_context_call> resultHandler) |
boolean |
ThriftHiveMetastore.Iface.drop_partition_with_environment_context(String db_name,
String tbl_name,
List<String> part_vals,
boolean deleteData,
EnvironmentContext environment_context) |
boolean |
ThriftHiveMetastore.Client.drop_partition_with_environment_context(String db_name,
String tbl_name,
List<String> part_vals,
boolean deleteData,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.AsyncIface.drop_partition_with_environment_context(String db_name,
String tbl_name,
List<String> part_vals,
boolean deleteData,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.drop_partition_with_environment_context(String db_name,
String tbl_name,
List<String> part_vals,
boolean deleteData,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.Iface.drop_table_with_environment_context(String dbname,
String name,
boolean deleteData,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.drop_table_with_environment_context(String dbname,
String name,
boolean deleteData,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.AsyncIface.drop_table_with_environment_context(String dbname,
String name,
boolean deleteData,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_table_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.drop_table_with_environment_context(String dbname,
String name,
boolean deleteData,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_table_with_environment_context_call> resultHandler) |
boolean |
EnvironmentContext.equals(EnvironmentContext that) |
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) |
void |
ThriftHiveMetastore.AsyncIface.get_fields_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call> resultHandler) |
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) |
void |
ThriftHiveMetastore.AsyncIface.get_schema_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call> resultHandler) |
void |
ThriftHiveMetastore.Client.send_add_partition_with_environment_context(Partition new_part,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.send_alter_partition_with_environment_context(String db_name,
String tbl_name,
Partition new_part,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.send_alter_table_with_environment_context(String dbname,
String tbl_name,
Table new_tbl,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.send_append_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.send_append_partition_with_environment_context(String db_name,
String tbl_name,
List<String> part_vals,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.send_create_table_with_environment_context(Table tbl,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.send_drop_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
boolean deleteData,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.send_drop_partition_with_environment_context(String db_name,
String tbl_name,
List<String> part_vals,
boolean deleteData,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.send_drop_table_with_environment_context(String dbname,
String name,
boolean deleteData,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.send_get_fields_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.Client.send_get_schema_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.get_fields_with_environment_context_args.setEnvironment_context(EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.get_schema_with_environment_context_args.setEnvironment_context(EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.create_table_with_environment_context_args.setEnvironment_context(EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.drop_table_with_environment_context_args.setEnvironment_context(EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.alter_table_with_environment_context_args.setEnvironment_context(EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.add_partition_with_environment_context_args.setEnvironment_context(EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.append_partition_with_environment_context_args.setEnvironment_context(EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.append_partition_by_name_with_environment_context_args.setEnvironment_context(EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.drop_partition_with_environment_context_args.setEnvironment_context(EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args.setEnvironment_context(EnvironmentContext environment_context) |
void |
ThriftHiveMetastore.alter_partition_with_environment_context_args.setEnvironment_context(EnvironmentContext environment_context) |
void |
DropPartitionsRequest.setEnvironmentContext(EnvironmentContext environmentContext) |
Constructor and Description |
---|
EnvironmentContext(EnvironmentContext other)
Performs a deep copy on other.
|
ThriftHiveMetastore.add_partition_with_environment_context_args(Partition new_part,
EnvironmentContext environment_context) |
ThriftHiveMetastore.alter_partition_with_environment_context_args(String db_name,
String tbl_name,
Partition new_part,
EnvironmentContext environment_context) |
ThriftHiveMetastore.alter_table_with_environment_context_args(String dbname,
String tbl_name,
Table new_tbl,
EnvironmentContext environment_context) |
ThriftHiveMetastore.append_partition_by_name_with_environment_context_args(String db_name,
String tbl_name,
String part_name,
EnvironmentContext environment_context) |
ThriftHiveMetastore.append_partition_with_environment_context_args(String db_name,
String tbl_name,
List<String> part_vals,
EnvironmentContext environment_context) |
ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call(Partition new_part,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context_call(String db_name,
String tbl_name,
Partition new_part,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context_call(String dbname,
String tbl_name,
Table new_tbl,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context_call(String db_name,
String tbl_name,
String part_name,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_by_name_with_environment_context_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context_call(String db_name,
String tbl_name,
List<String> part_vals,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_with_environment_context_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call(Table tbl,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.AsyncClient.drop_partition_by_name_with_environment_context_call(String db_name,
String tbl_name,
String part_name,
boolean deleteData,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_by_name_with_environment_context_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.AsyncClient.drop_partition_with_environment_context_call(String db_name,
String tbl_name,
List<String> part_vals,
boolean deleteData,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_with_environment_context_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.AsyncClient.drop_table_with_environment_context_call(String dbname,
String name,
boolean deleteData,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_table_with_environment_context_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call(String db_name,
String table_name,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call(String db_name,
String table_name,
EnvironmentContext environment_context,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.create_table_with_environment_context_args(Table tbl,
EnvironmentContext environment_context) |
ThriftHiveMetastore.drop_partition_by_name_with_environment_context_args(String db_name,
String tbl_name,
String part_name,
boolean deleteData,
EnvironmentContext environment_context) |
ThriftHiveMetastore.drop_partition_with_environment_context_args(String db_name,
String tbl_name,
List<String> part_vals,
boolean deleteData,
EnvironmentContext environment_context) |
ThriftHiveMetastore.drop_table_with_environment_context_args(String dbname,
String name,
boolean deleteData,
EnvironmentContext environment_context) |
ThriftHiveMetastore.get_fields_with_environment_context_args(String db_name,
String table_name,
EnvironmentContext environment_context) |
ThriftHiveMetastore.get_schema_with_environment_context_args(String db_name,
String table_name,
EnvironmentContext environment_context) |
Modifier and Type | Method and Description |
---|---|
EnvironmentContext |
ListenerEvent.getEnvironmentContext() |
Modifier and Type | Method and Description |
---|---|
void |
ListenerEvent.setEnvironmentContext(EnvironmentContext environmentContext) |
Modifier and Type | Method and Description |
---|---|
void |
SessionHiveMetaStoreClient.alter_table(String dbname,
String tbl_name,
Table new_tbl,
EnvironmentContext envContext) |
protected void |
SessionHiveMetaStoreClient.create_table_with_environment_context(Table tbl,
EnvironmentContext envContext) |
protected void |
SessionHiveMetaStoreClient.drop_table_with_environment_context(String dbname,
String name,
boolean deleteData,
EnvironmentContext envContext) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.