Modifier and Type | Method and Description |
---|---|
Index |
HiveMetaStore.HMSHandler.add_index(Index newIndex,
Table indexTable) |
Index |
MetaStoreFilterHook.filterIndex(Index index) |
Index |
DefaultMetaStoreFilterHookImpl.filterIndex(Index index) |
Index |
HiveMetaStore.HMSHandler.get_index_by_name(String dbName,
String tblName,
String indexName) |
Index |
RawStore.getIndex(String dbName,
String origTableName,
String indexName) |
Index |
ObjectStore.getIndex(String dbName,
String origTableName,
String indexName) |
Index |
IMetaStoreClient.getIndex(String dbName,
String tblName,
String indexName) |
Index |
HiveMetaStoreClient.getIndex(String dbName,
String tblName,
String indexName) |
Modifier and Type | Method and Description |
---|---|
List<Index> |
MetaStoreFilterHook.filterIndexes(List<Index> indexeList)
Filter given list of index objects
|
List<Index> |
DefaultMetaStoreFilterHookImpl.filterIndexes(List<Index> indexeList) |
List<Index> |
HiveMetaStore.HMSHandler.get_indexes(String dbName,
String tblName,
short maxIndexes) |
List<Index> |
RawStore.getIndexes(String dbName,
String origTableName,
int max) |
List<Index> |
ObjectStore.getIndexes(String dbName,
String origTableName,
int max) |
List<Index> |
IMetaStoreClient.listIndexes(String db_name,
String tbl_name,
short max)
list indexes of the give base table
|
List<Index> |
HiveMetaStoreClient.listIndexes(String dbName,
String tblName,
short max)
list all the index names of the give base table.
|
Modifier and Type | Method and Description |
---|---|
Index |
HiveMetaStore.HMSHandler.add_index(Index newIndex,
Table indexTable) |
boolean |
RawStore.addIndex(Index index) |
boolean |
ObjectStore.addIndex(Index index) |
void |
IMetaStoreClient.alter_index(String dbName,
String tblName,
String indexName,
Index index) |
void |
HiveMetaStoreClient.alter_index(String dbname,
String base_tbl_name,
String idx_name,
Index new_idx) |
void |
HiveMetaStore.HMSHandler.alter_index(String dbname,
String base_table_name,
String index_name,
Index newIndex) |
void |
RawStore.alterIndex(String dbname,
String baseTblName,
String name,
Index newIndex) |
void |
ObjectStore.alterIndex(String dbname,
String baseTblName,
String name,
Index newIndex) |
void |
IMetaStoreClient.createIndex(Index index,
Table indexTable)
create an index
|
void |
HiveMetaStoreClient.createIndex(Index index,
Table indexTable)
create an index
|
Index |
MetaStoreFilterHook.filterIndex(Index index) |
Index |
DefaultMetaStoreFilterHookImpl.filterIndex(Index index) |
Modifier and Type | Method and Description |
---|---|
List<Index> |
MetaStoreFilterHook.filterIndexes(List<Index> indexeList)
Filter given list of index objects
|
List<Index> |
DefaultMetaStoreFilterHookImpl.filterIndexes(List<Index> indexeList) |
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) |
Index |
Index.deepCopy() |
Index |
ThriftHiveMetastore.Iface.get_index_by_name(String db_name,
String tbl_name,
String index_name) |
Index |
ThriftHiveMetastore.Client.get_index_by_name(String db_name,
String tbl_name,
String index_name) |
Index |
ThriftHiveMetastore.alter_index_args.getNew_idx() |
Index |
ThriftHiveMetastore.add_index_args.getNew_index() |
Index |
ThriftHiveMetastore.AsyncClient.add_index_call.getResult() |
Index |
ThriftHiveMetastore.AsyncClient.get_index_by_name_call.getResult() |
Index |
ThriftHiveMetastore.add_index_result.getSuccess() |
Index |
ThriftHiveMetastore.get_index_by_name_result.getSuccess() |
Index |
ThriftHiveMetastore.Client.recv_add_index() |
Index |
ThriftHiveMetastore.Client.recv_get_index_by_name() |
Modifier and Type | Method and Description |
---|---|
List<Index> |
ThriftHiveMetastore.Iface.get_indexes(String db_name,
String tbl_name,
short max_indexes) |
List<Index> |
ThriftHiveMetastore.Client.get_indexes(String db_name,
String tbl_name,
short max_indexes) |
List<Index> |
ThriftHiveMetastore.AsyncClient.get_indexes_call.getResult() |
List<Index> |
ThriftHiveMetastore.get_indexes_result.getSuccess() |
Iterator<Index> |
ThriftHiveMetastore.get_indexes_result.getSuccessIterator() |
List<Index> |
ThriftHiveMetastore.Client.recv_get_indexes() |
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) |
void |
ThriftHiveMetastore.AsyncIface.add_index(Index new_index,
Table index_table,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_index_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.add_index(Index new_index,
Table index_table,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_index_call> resultHandler) |
void |
ThriftHiveMetastore.get_indexes_result.addToSuccess(Index elem) |
void |
ThriftHiveMetastore.Iface.alter_index(String dbname,
String base_tbl_name,
String idx_name,
Index new_idx) |
void |
ThriftHiveMetastore.Client.alter_index(String dbname,
String base_tbl_name,
String idx_name,
Index new_idx) |
void |
ThriftHiveMetastore.AsyncIface.alter_index(String dbname,
String base_tbl_name,
String idx_name,
Index new_idx,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_index_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.alter_index(String dbname,
String base_tbl_name,
String idx_name,
Index new_idx,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_index_call> resultHandler) |
int |
Index.compareTo(Index other) |
boolean |
Index.equals(Index that) |
void |
ThriftHiveMetastore.Client.send_add_index(Index new_index,
Table index_table) |
void |
ThriftHiveMetastore.Client.send_alter_index(String dbname,
String base_tbl_name,
String idx_name,
Index new_idx) |
void |
ThriftHiveMetastore.alter_index_args.setNew_idx(Index new_idx) |
void |
ThriftHiveMetastore.add_index_args.setNew_index(Index new_index) |
void |
ThriftHiveMetastore.add_index_result.setSuccess(Index success) |
void |
ThriftHiveMetastore.get_index_by_name_result.setSuccess(Index success) |
Modifier and Type | Method and Description |
---|---|
void |
ThriftHiveMetastore.get_indexes_result.setSuccess(List<Index> success) |
Constructor and Description |
---|
Index(Index other)
Performs a deep copy on other.
|
ThriftHiveMetastore.add_index_args(Index new_index,
Table index_table) |
ThriftHiveMetastore.add_index_result(Index success,
InvalidObjectException o1,
AlreadyExistsException o2,
MetaException o3) |
ThriftHiveMetastore.alter_index_args(String dbname,
String base_tbl_name,
String idx_name,
Index new_idx) |
ThriftHiveMetastore.AsyncClient.add_index_call(Index new_index,
Table index_table,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_index_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.AsyncClient.alter_index_call(String dbname,
String base_tbl_name,
String idx_name,
Index new_idx,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_index_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.get_index_by_name_result(Index success,
MetaException o1,
NoSuchObjectException o2) |
Constructor and Description |
---|
ThriftHiveMetastore.get_indexes_result(List<Index> success,
NoSuchObjectException o1,
MetaException o2) |
Modifier and Type | Method and Description |
---|---|
Index |
PreDropIndexEvent.getIndex() |
Index |
PreAddIndexEvent.getIndex() |
Index |
DropIndexEvent.getIndex() |
Index |
AddIndexEvent.getIndex() |
Index |
PreAlterIndexEvent.getNewIndex() |
Index |
AlterIndexEvent.getNewIndex() |
Index |
PreAlterIndexEvent.getOldIndex() |
Index |
AlterIndexEvent.getOldIndex() |
Constructor and Description |
---|
AddIndexEvent(Index index,
boolean status,
HiveMetaStore.HMSHandler handler) |
AlterIndexEvent(Index oldIndex,
Index newIndex,
boolean status,
HiveMetaStore.HMSHandler handler) |
DropIndexEvent(Index index,
boolean status,
HiveMetaStore.HMSHandler handler) |
PreAddIndexEvent(Index table,
HiveMetaStore.HMSHandler handler) |
PreAlterIndexEvent(Index oldIndex,
Index newIndex,
HiveMetaStore.HMSHandler handler) |
PreDropIndexEvent(Index index,
HiveMetaStore.HMSHandler handler) |
Modifier and Type | Method and Description |
---|---|
void |
HiveIndexHandler.analyzeIndexDefinition(Table baseTable,
Index index,
Table indexTable)
Requests that the handler validate an index definition and fill in
additional information about its stored representation.
|
void |
AggregateIndexHandler.analyzeIndexDefinition(Table baseTable,
Index index,
Table indexTable) |
List<Task<?>> |
TableBasedIndexHandler.generateIndexBuildTaskList(Table baseTbl,
Index index,
List<Partition> indexTblPartitions,
List<Partition> baseTblPartitions,
Table indexTbl,
Set<ReadEntity> inputs,
Set<WriteEntity> outputs) |
List<Task<?>> |
HiveIndexHandler.generateIndexBuildTaskList(Table baseTbl,
Index index,
List<Partition> indexTblPartitions,
List<Partition> baseTblPartitions,
Table indexTbl,
Set<ReadEntity> inputs,
Set<WriteEntity> outputs)
Requests that the handler generate a plan for building the index; the plan
should read the base table and write out the index representation.
|
void |
AbstractIndexHandler.generateIndexQuery(Index index,
ExprNodeDesc predicate,
ParseContext pctx,
HiveIndexQueryContext queryContext) |
protected Task<?> |
TableBasedIndexHandler.getIndexBuilderMapRedTask(Set<ReadEntity> inputs,
Set<WriteEntity> outputs,
Index index,
boolean partitioned,
PartitionDesc indexTblPartDesc,
String indexTableName,
PartitionDesc baseTablePartDesc,
String baseTableName,
String dbName) |
protected Task<?> |
AggregateIndexHandler.getIndexBuilderMapRedTask(Set<ReadEntity> inputs,
Set<WriteEntity> outputs,
Index index,
boolean partitioned,
PartitionDesc indexTblPartDesc,
String indexTableName,
PartitionDesc baseTablePartDesc,
String baseTableName,
String dbName) |
Modifier and Type | Method and Description |
---|---|
void |
HiveIndexHandler.generateIndexQuery(List<Index> indexes,
ExprNodeDesc predicate,
ParseContext pctx,
HiveIndexQueryContext queryContext)
Generate the list of tasks required to run an index optimized sub-query for the
given predicate, using the given indexes.
|
Modifier and Type | Method and Description |
---|---|
void |
BitmapIndexHandler.analyzeIndexDefinition(Table baseTable,
Index index,
Table indexTable) |
Modifier and Type | Method and Description |
---|---|
void |
BitmapIndexHandler.generateIndexQuery(List<Index> indexes,
ExprNodeDesc predicate,
ParseContext pctx,
HiveIndexQueryContext queryContext) |
Modifier and Type | Method and Description |
---|---|
void |
CompactIndexHandler.analyzeIndexDefinition(Table baseTable,
Index index,
Table indexTable) |
Modifier and Type | Method and Description |
---|---|
void |
CompactIndexHandler.generateIndexQuery(List<Index> indexes,
ExprNodeDesc predicate,
ParseContext pctx,
HiveIndexQueryContext queryContext) |
Modifier and Type | Method and Description |
---|---|
Index |
Hive.getIndex(String baseTableName,
String indexName) |
Index |
Hive.getIndex(String dbName,
String baseTableName,
String indexName) |
Modifier and Type | Method and Description |
---|---|
List<Index> |
Hive.getIndexes(String dbName,
String tblName,
short max) |
Modifier and Type | Method and Description |
---|---|
void |
Hive.alterIndex(String baseTableName,
String indexName,
Index newIdx) |
void |
Hive.alterIndex(String dbName,
String baseTblName,
String idxName,
Index newIdx)
Updates the existing index metadata with the new metadata.
|
Modifier and Type | Method and Description |
---|---|
static String |
MetaDataFormatUtils.getAllColumnsInformation(Index index) |
Modifier and Type | Method and Description |
---|---|
static List<Index> |
IndexUtils.getAllIndexes(Table table,
short max) |
static List<Index> |
IndexUtils.getIndexes(Table baseTableMetaData,
List<String> matchIndexTypes)
Get a list of indexes on a table that match given types.
|
Modifier and Type | Method and Description |
---|---|
static Set<Partition> |
IndexUtils.checkPartitionsCoveredByIndex(TableScanOperator tableScan,
ParseContext pctx,
List<Index> indexes)
Check the partitions used by the table scan to make sure they also exist in the
index table.
|
Constructor and Description |
---|
IndexWhereProcessor(Map<TableScanOperator,List<Index>> tsToIndices) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.