public class SharedCache extends Object
| Constructor and Description |
|---|
SharedCache() |
| Modifier and Type | Method and Description |
|---|---|
void |
addAggregateStatsToCache(String catName,
String dbName,
String tblName,
org.apache.hadoop.hive.metastore.api.AggrStats aggrStatsAllPartitions,
org.apache.hadoop.hive.metastore.api.AggrStats aggrStatsAllButDefaultPartition) |
void |
addCatalogToCache(org.apache.hadoop.hive.metastore.api.Catalog cat) |
void |
addDatabaseToCache(org.apache.hadoop.hive.metastore.api.Database db) |
void |
addPartitionsToCache(String catName,
String dbName,
String tblName,
List<org.apache.hadoop.hive.metastore.api.Partition> parts) |
void |
addPartitionToCache(String catName,
String dbName,
String tblName,
org.apache.hadoop.hive.metastore.api.Partition part) |
org.apache.hadoop.hive.metastore.cache.SharedCache.TableWrapper |
addTableToCache(String catName,
String dbName,
String tblName,
org.apache.hadoop.hive.metastore.api.Table tbl) |
void |
alterCatalogInCache(String catName,
org.apache.hadoop.hive.metastore.api.Catalog newCat) |
void |
alterDatabaseInCache(String catName,
String dbName,
org.apache.hadoop.hive.metastore.api.Database newDb)
Replaces the old db object with the new one.
|
void |
alterPartitionInCache(String catName,
String dbName,
String tblName,
List<String> partVals,
org.apache.hadoop.hive.metastore.api.Partition newPart) |
void |
alterPartitionsInCache(String catName,
String dbName,
String tblName,
List<List<String>> partValsList,
List<org.apache.hadoop.hive.metastore.api.Partition> newParts) |
void |
alterTableInCache(String catName,
String dbName,
String tblName,
org.apache.hadoop.hive.metastore.api.Table newTable) |
void |
completeTableCachePrewarm() |
void |
decrSd(byte[] sdHash) |
boolean |
existPartitionFromCache(String catName,
String dbName,
String tblName,
List<String> partVals) |
List<org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj> |
getAggrStatsFromCache(String catName,
String dbName,
String tblName,
List<String> colNames,
org.apache.hadoop.hive.metastore.cache.SharedCache.StatsType statsType) |
int |
getCachedDatabaseCount() |
int |
getCachedTableCount() |
org.apache.hadoop.hive.metastore.api.Catalog |
getCatalogFromCache(String name) |
org.apache.hadoop.hive.metastore.api.Database |
getDatabaseFromCache(String catName,
String name) |
org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj |
getPartitionColStatsFromCache(String catName,
String dbName,
String tblName,
List<String> partVal,
String colName) |
org.apache.hadoop.hive.metastore.api.Partition |
getPartitionFromCache(String catName,
String dbName,
String tblName,
List<String> partVals) |
org.apache.hadoop.hive.metastore.api.StorageDescriptor |
getSdFromCache(byte[] sdHash) |
List<org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj> |
getTableColStatsFromCache(String catName,
String dbName,
String tblName,
List<String> colNames) |
org.apache.hadoop.hive.metastore.api.Table |
getTableFromCache(String catName,
String dbName,
String tableName) |
List<org.apache.hadoop.hive.metastore.api.TableMeta> |
getTableMeta(String catName,
String dbNames,
String tableNames,
List<String> tableTypes) |
long |
getUpdateCount() |
void |
incrementUpdateCount() |
void |
increSd(org.apache.hadoop.hive.metastore.api.StorageDescriptor sd,
byte[] sdHash) |
void |
initialize(long maxSharedCacheSizeInBytes) |
boolean |
isCatalogCachePrewarmed() |
boolean |
isDatabaseCachePrewarmed() |
List<String> |
listCachedCatalogs() |
List<String> |
listCachedDatabases(String catName) |
List<String> |
listCachedDatabases(String catName,
String pattern) |
List<org.apache.hadoop.hive.metastore.api.Partition> |
listCachedPartitions(String catName,
String dbName,
String tblName,
int max) |
List<String> |
listCachedTableNames(String catName,
String dbName) |
List<String> |
listCachedTableNames(String catName,
String dbName,
String pattern,
short maxTables) |
List<String> |
listCachedTableNames(String catName,
String dbName,
String pattern,
TableType tableType) |
List<org.apache.hadoop.hive.metastore.api.Table> |
listCachedTables(String catName,
String dbName) |
void |
populateCatalogsInCache(Collection<org.apache.hadoop.hive.metastore.api.Catalog> catalogs) |
void |
populateDatabasesInCache(List<org.apache.hadoop.hive.metastore.api.Database> databases) |
boolean |
populateTableInCache(org.apache.hadoop.hive.metastore.api.Table table,
org.apache.hadoop.hive.metastore.api.ColumnStatistics tableColStats,
List<org.apache.hadoop.hive.metastore.api.Partition> partitions,
List<org.apache.hadoop.hive.metastore.api.ColumnStatistics> partitionColStats,
org.apache.hadoop.hive.metastore.api.AggrStats aggrStatsAllPartitions,
org.apache.hadoop.hive.metastore.api.AggrStats aggrStatsAllButDefaultPartition) |
void |
refreshAggregateStatsInCache(String catName,
String dbName,
String tblName,
org.apache.hadoop.hive.metastore.api.AggrStats aggrStatsAllPartitions,
org.apache.hadoop.hive.metastore.api.AggrStats aggrStatsAllButDefaultPartition) |
void |
refreshDatabasesInCache(List<org.apache.hadoop.hive.metastore.api.Database> databases) |
void |
refreshPartitionColStatsInCache(String catName,
String dbName,
String tblName,
List<org.apache.hadoop.hive.metastore.api.ColumnStatistics> partitionColStats) |
void |
refreshPartitionsInCache(String catName,
String dbName,
String tblName,
List<org.apache.hadoop.hive.metastore.api.Partition> partitions) |
void |
refreshTableColStatsInCache(String catName,
String dbName,
String tableName,
List<org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj> colStatsForTable) |
void |
refreshTablesInCache(String catName,
String dbName,
List<org.apache.hadoop.hive.metastore.api.Table> tables) |
void |
removeCatalogFromCache(String name) |
void |
removeDatabaseFromCache(String catName,
String dbName) |
void |
removePartitionColStatsFromCache(String catName,
String dbName,
String tblName,
List<String> partVals,
String colName) |
org.apache.hadoop.hive.metastore.api.Partition |
removePartitionFromCache(String catName,
String dbName,
String tblName,
List<String> partVals) |
void |
removePartitionsFromCache(String catName,
String dbName,
String tblName,
List<List<String>> partVals) |
void |
removeTableColStatsFromCache(String catName,
String dbName,
String tblName,
String colName) |
void |
removeTableFromCache(String catName,
String dbName,
String tblName) |
void |
updatePartitionColStatsInCache(String catName,
String dbName,
String tableName,
List<String> partVals,
List<org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj> colStatsObjs) |
void |
updateTableColStatsInCache(String catName,
String dbName,
String tableName,
List<org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj> colStatsForTable) |
public void initialize(long maxSharedCacheSizeInBytes)
public void populateCatalogsInCache(Collection<org.apache.hadoop.hive.metastore.api.Catalog> catalogs)
public org.apache.hadoop.hive.metastore.api.Catalog getCatalogFromCache(String name)
public void addCatalogToCache(org.apache.hadoop.hive.metastore.api.Catalog cat)
public void alterCatalogInCache(String catName, org.apache.hadoop.hive.metastore.api.Catalog newCat)
public void removeCatalogFromCache(String name)
public boolean isCatalogCachePrewarmed()
public org.apache.hadoop.hive.metastore.api.Database getDatabaseFromCache(String catName, String name)
public void populateDatabasesInCache(List<org.apache.hadoop.hive.metastore.api.Database> databases)
public boolean isDatabaseCachePrewarmed()
public void addDatabaseToCache(org.apache.hadoop.hive.metastore.api.Database db)
public void alterDatabaseInCache(String catName, String dbName, org.apache.hadoop.hive.metastore.api.Database newDb)
public void refreshDatabasesInCache(List<org.apache.hadoop.hive.metastore.api.Database> databases)
public int getCachedDatabaseCount()
public boolean populateTableInCache(org.apache.hadoop.hive.metastore.api.Table table,
org.apache.hadoop.hive.metastore.api.ColumnStatistics tableColStats,
List<org.apache.hadoop.hive.metastore.api.Partition> partitions,
List<org.apache.hadoop.hive.metastore.api.ColumnStatistics> partitionColStats,
org.apache.hadoop.hive.metastore.api.AggrStats aggrStatsAllPartitions,
org.apache.hadoop.hive.metastore.api.AggrStats aggrStatsAllButDefaultPartition)
public void completeTableCachePrewarm()
public org.apache.hadoop.hive.metastore.api.Table getTableFromCache(String catName, String dbName, String tableName)
public org.apache.hadoop.hive.metastore.cache.SharedCache.TableWrapper addTableToCache(String catName, String dbName, String tblName, org.apache.hadoop.hive.metastore.api.Table tbl)
public void removeTableFromCache(String catName, String dbName, String tblName)
public void alterTableInCache(String catName, String dbName, String tblName, org.apache.hadoop.hive.metastore.api.Table newTable)
public List<org.apache.hadoop.hive.metastore.api.Table> listCachedTables(String catName, String dbName)
public List<String> listCachedTableNames(String catName, String dbName, String pattern, short maxTables)
public List<String> listCachedTableNames(String catName, String dbName, String pattern, TableType tableType)
public void refreshTablesInCache(String catName, String dbName, List<org.apache.hadoop.hive.metastore.api.Table> tables)
public List<org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj> getTableColStatsFromCache(String catName, String dbName, String tblName, List<String> colNames)
public void removeTableColStatsFromCache(String catName, String dbName, String tblName, String colName)
public void updateTableColStatsInCache(String catName, String dbName, String tableName, List<org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj> colStatsForTable)
public void refreshTableColStatsInCache(String catName, String dbName, String tableName, List<org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj> colStatsForTable)
public int getCachedTableCount()
public List<org.apache.hadoop.hive.metastore.api.TableMeta> getTableMeta(String catName, String dbNames, String tableNames, List<String> tableTypes)
public void addPartitionToCache(String catName, String dbName, String tblName, org.apache.hadoop.hive.metastore.api.Partition part)
public void addPartitionsToCache(String catName, String dbName, String tblName, List<org.apache.hadoop.hive.metastore.api.Partition> parts)
public org.apache.hadoop.hive.metastore.api.Partition getPartitionFromCache(String catName, String dbName, String tblName, List<String> partVals)
public boolean existPartitionFromCache(String catName, String dbName, String tblName, List<String> partVals)
public org.apache.hadoop.hive.metastore.api.Partition removePartitionFromCache(String catName, String dbName, String tblName, List<String> partVals)
public void removePartitionsFromCache(String catName, String dbName, String tblName, List<List<String>> partVals)
public List<org.apache.hadoop.hive.metastore.api.Partition> listCachedPartitions(String catName, String dbName, String tblName, int max)
public void alterPartitionInCache(String catName, String dbName, String tblName, List<String> partVals, org.apache.hadoop.hive.metastore.api.Partition newPart)
public void alterPartitionsInCache(String catName, String dbName, String tblName, List<List<String>> partValsList, List<org.apache.hadoop.hive.metastore.api.Partition> newParts)
public void refreshPartitionsInCache(String catName, String dbName, String tblName, List<org.apache.hadoop.hive.metastore.api.Partition> partitions)
public void removePartitionColStatsFromCache(String catName, String dbName, String tblName, List<String> partVals, String colName)
public void updatePartitionColStatsInCache(String catName, String dbName, String tableName, List<String> partVals, List<org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj> colStatsObjs)
public org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj getPartitionColStatsFromCache(String catName, String dbName, String tblName, List<String> partVal, String colName)
public void refreshPartitionColStatsInCache(String catName, String dbName, String tblName, List<org.apache.hadoop.hive.metastore.api.ColumnStatistics> partitionColStats)
public List<org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj> getAggrStatsFromCache(String catName, String dbName, String tblName, List<String> colNames, org.apache.hadoop.hive.metastore.cache.SharedCache.StatsType statsType)
public void addAggregateStatsToCache(String catName, String dbName, String tblName, org.apache.hadoop.hive.metastore.api.AggrStats aggrStatsAllPartitions, org.apache.hadoop.hive.metastore.api.AggrStats aggrStatsAllButDefaultPartition)
public void refreshAggregateStatsInCache(String catName, String dbName, String tblName, org.apache.hadoop.hive.metastore.api.AggrStats aggrStatsAllPartitions, org.apache.hadoop.hive.metastore.api.AggrStats aggrStatsAllButDefaultPartition)
public void increSd(org.apache.hadoop.hive.metastore.api.StorageDescriptor sd,
byte[] sdHash)
public void decrSd(byte[] sdHash)
public org.apache.hadoop.hive.metastore.api.StorageDescriptor getSdFromCache(byte[] sdHash)
public long getUpdateCount()
public void incrementUpdateCount()
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.