Impala
Impalaistheopensource,nativeanalyticdatabaseforApacheHadoop.
|
Public Member Functions | |
void | load (Table oldValue, HiveMetaStoreClient client, org.apache.hadoop.hive.metastore.api.Table msTbl) throws TableLoadingException |
synchronized Pair< Long, Long > | getEstimatedRowStats (byte[] startRowKey, byte[] endRowKey) |
long | getHdfsSize (HRegionInfo info) throws IOException |
ArrayList< Column > | getColumnsInHiveOrder () |
TTableDescriptor | toThriftDescriptor (Set< Long > referencedPartitions) |
String | getHBaseTableName () |
HTable | getHTable () |
int | getNumNodes () |
TCatalogObjectType | getCatalogObjectType () |
TTable | toThrift () |
String | getStorageHandlerClassName () |
TResultSet | getTableStats () |
void | addColumn (Column col) |
void | clearColumns () |
void | updateLastDdlTime (long ddlTime) |
void | validate () throws TableLoadingException |
TCatalogObject | toTCatalogObject () |
Db | getDb () |
String | getName () |
String | getFullName () |
TableName | getTableName () |
String | getOwner () |
ArrayList< Column > | getColumns () |
List< String > | getColumnNames () |
List< Column > | getNonClusteringColumns () |
Column | getColumn (String name) |
org.apache.hadoop.hive.metastore.api.Table | getMetaStoreTable () |
int | getNumClusteringCols () |
TableId | getId () |
long | getNumRows () |
ArrayType | getType () |
long | getCatalogVersion () |
void | setCatalogVersion (long catalogVersion) |
boolean | isLoaded () |
Static Public Member Functions | |
static Path | getRootDir (final Configuration c) throws IOException |
static Configuration | getHBaseConf () |
static List< HRegionLocation > | getRegionsInRange (HTable hbaseTbl, final byte[] startKey, final byte[] endKey) throws IOException |
static boolean | isHBaseTable (org.apache.hadoop.hive.metastore.api.Table msTbl) |
static Table | fromMetastoreTable (TableId id, Db db, org.apache.hadoop.hive.metastore.api.Table msTbl) |
static Table | fromThrift (Db parentDb, TTable thriftTable) throws TableLoadingException |
Static Public Attributes | |
static final String | DEFAULT_PREFIX = "default." |
static final int | ROW_COUNT_ESTIMATE_BATCH_SIZE = 10 |
Protected Member Functions | |
HBaseTable (TableId id, org.apache.hadoop.hive.metastore.api.Table msTbl, Db db, String name, String owner) | |
void | loadFromThrift (TTable table) throws TableLoadingException |
List< String > | getColumnNamesWithHmsStats () |
void | loadAllColumnStats (HiveMetaStoreClient client) |
Type | parseColumnType (FieldSchema fs) throws TableLoadingException |
Static Protected Member Functions | |
static long | getRowCount (Map< String, String > parameters) |
Protected Attributes | |
HBaseColumn | rowKey_ |
String | hbaseTableName_ |
final org.apache.hadoop.hive.metastore.api.Table | msTable_ |
final TableId | id_ |
final Db | db_ |
final String | name_ |
final String | owner_ |
TTableDescriptor | tableDesc_ |
List< FieldSchema > | fields_ |
TAccessLevel | accessLevel_ = TAccessLevel.READ_WRITE |
int | numClusteringCols_ |
long | numRows_ = -1 |
final ArrayType | type_ = new ArrayType(new StructType()) |
long | lastDdlTime_ |
Static Protected Attributes | |
static EnumSet< TableType > | SUPPORTED_TABLE_TYPES |
Private Member Functions | |
void | parseColumnMapping (boolean tableDefaultStorageIsBinary, String columnsMappingSpec, List< FieldSchema > fieldSchemas, List< String > columnFamilies, List< String > columnQualifiers, List< Boolean > colIsBinaryEncoded) throws SerDeException |
boolean | supportsBinaryEncoding (FieldSchema fs) |
String | getHBaseTableName (org.apache.hadoop.hive.metastore.api.Table tbl) |
Pair< Long, Long > | getEstimatedRowStatsForRegion (HRegionLocation location, boolean isCompressed) throws IOException |
THBaseTable | getTHBaseTable () |
Private Attributes | |
HTable | hTable_ = null |
HColumnDescriptor[] | columnFamilies_ = null |
Static Private Attributes | |
static final double | DELTA_FROM_AVERAGE = 0.15 |
static final Logger | LOG = Logger.getLogger(HBaseTable.class) |
static final int | MIN_NUM_REGIONS_TO_CHECK = 5 |
static final String | HBASE_INPUT_FORMAT |
static final String | HBASE_SERIALIZATION_LIB |
static final String | HBASE_STORAGE_HANDLER |
static final String | ROW_KEY_COLUMN_FAMILY = ":key" |
static final Configuration | hbaseConf_ = HBaseConfiguration.create() |
Impala representation of HBase table metadata, as loaded from Hive's metastore. This implies that we inherit the metastore's limitations related to HBase, for example the lack of support for composite HBase row keys. We sort the HBase columns (cols) by family/qualifier to simplify the retrieval logic in the backend, since HBase returns data ordered by family/qualifier. This implies that a "select *"-query on an HBase table will not have the columns ordered as they were declared in the DDL. They will be ordered by family/qualifier.
Definition at line 76 of file HBaseTable.java.
|
inlineprotected |
Definition at line 123 of file HBaseTable.java.
|
inlineinherited |
Definition at line 114 of file Table.java.
References com.cloudera.impala.catalog.ArrayType.getItemType(), and com.cloudera.impala.catalog.Table.type_.
Referenced by com.cloudera.impala.catalog.View.load(), com.cloudera.impala.catalog.HBaseTable.load(), com.cloudera.impala.catalog.DataSourceTable.loadColumns(), and com.cloudera.impala.catalog.HdfsTable.loadColumns().
|
inlineinherited |
Definition at line 121 of file Table.java.
References com.cloudera.impala.catalog.ArrayType.getItemType(), and com.cloudera.impala.catalog.Table.type_.
Referenced by com.cloudera.impala.catalog.HBaseTable.load().
|
inlinestaticinherited |
Creates a table of the appropriate type based on the given hive.metastore.api.Table object.
Definition at line 207 of file Table.java.
References com.cloudera.impala.catalog.DataSourceTable.isDataSourceTable(), com.cloudera.impala.catalog.HBaseTable.isHBaseTable(), and com.cloudera.impala.catalog.HdfsFileFormat.isHdfsFormatClass().
|
inlinestaticinherited |
Factory method that creates a new Table from its Thrift representation. Determines the type of table to create based on the Thrift table provided.
Definition at line 231 of file Table.java.
|
inline |
Implements com.cloudera.impala.catalog.CatalogObject.
Definition at line 605 of file HBaseTable.java.
|
inlineinherited |
Implements com.cloudera.impala.catalog.CatalogObject.
Definition at line 408 of file Table.java.
References com.cloudera.impala.catalog.Table.catalogVersion_.
Referenced by com.cloudera.impala.catalog.CatalogServiceCatalog.dropPartition(), com.cloudera.impala.catalog.CatalogServiceCatalog.getCatalogObjects(), com.cloudera.impala.catalog.ImpaladCatalog.removeTable(), com.cloudera.impala.catalog.CatalogServiceCatalog.replaceTableIfUnchanged(), and com.cloudera.impala.catalog.Table.toTCatalogObject().
|
inlineinherited |
Case-insensitive lookup.
Definition at line 392 of file Table.java.
Referenced by com.cloudera.impala.catalog.Table.loadAllColumnStats(), and com.cloudera.impala.catalog.CatalogTest.testColStatsColTypeMismatch().
|
inlineinherited |
Returns a list of the column names ordered by position.
Definition at line 354 of file Table.java.
References com.cloudera.impala.catalog.Table.colsByPos_.
Referenced by com.cloudera.impala.analysis.ColumnLineageGraph.addTargetColumnLabels(), com.cloudera.impala.catalog.HdfsTable.getTHdfsTable(), com.cloudera.impala.catalog.DataSourceTable.toThriftDescriptor(), com.cloudera.impala.catalog.HBaseTable.toThriftDescriptor(), and com.cloudera.impala.catalog.HdfsTable.toThriftDescriptor().
|
inlineprotectedinherited |
Definition at line 144 of file Table.java.
References com.cloudera.impala.catalog.Table.colsByName_, and impala.name.
Referenced by com.cloudera.impala.catalog.Table.loadAllColumnStats().
|
inlineinherited |
Definition at line 349 of file Table.java.
References com.cloudera.impala.catalog.Table.colsByPos_.
Referenced by com.cloudera.impala.service.CatalogOpExecutor.alterTableOrViewRename(), com.cloudera.impala.analysis.InsertStmt.checkColumnCoverage(), com.cloudera.impala.catalog.HdfsTable.createPartition(), com.cloudera.impala.catalog.HdfsTable.dropPartition(), com.cloudera.impala.catalog.HdfsTable.getColumnNamesWithHmsStats(), com.cloudera.impala.catalog.HBaseTable.getColumnsInHiveOrder(), com.cloudera.impala.catalog.HdfsTable.getTableStats(), com.cloudera.impala.catalog.HBaseTable.getTHBaseTable(), com.cloudera.impala.analysis.InsertStmt.prepareExpressions(), com.cloudera.impala.catalog.HdfsTable.resetPartitionMd(), com.cloudera.impala.catalog.DataSourceTable.toThriftDescriptor(), com.cloudera.impala.catalog.HBaseTable.toThriftDescriptor(), com.cloudera.impala.catalog.HdfsTable.toThriftDescriptor(), and com.cloudera.impala.catalog.HdfsTable.updatePartitionMdAndColStats().
|
inline |
Hive returns the columns in order of their declaration for HBase tables.
Definition at line 572 of file HBaseTable.java.
References com.cloudera.impala.catalog.Table.getColumns().
|
inlineinherited |
Definition at line 341 of file Table.java.
References com.cloudera.impala.catalog.Table.db_.
Referenced by com.cloudera.impala.service.CatalogOpExecutor.alterTableUpdateStats(), com.cloudera.impala.service.CatalogOpExecutor.createHiveColStats(), com.cloudera.impala.analysis.Analyzer.getTable(), com.cloudera.impala.analysis.InsertStmt.setTargetTable(), com.cloudera.impala.analysis.ShowStatsStmt.toThrift(), com.cloudera.impala.analysis.ComputeStatsStmt.toThrift(), and com.cloudera.impala.service.CatalogOpExecutor.updateCatalog().
|
inline |
Get an estimate of the number of rows and bytes per row in regions between startRowKey and endRowKey.
This number is calculated by incrementally checking as many region servers as necessary until we observe a relatively constant row size per region on average. Depending on the skew of data in the regions this can either mean that we need to check only a minimal number of regions or that we will scan all regions.
The accuracy of this number is determined by the number of rows that are written and kept in the memstore and have not been flushed until now. A large number of key-value pairs in the memstore will lead to bad estimates as this number is not reflected in the file size on HDFS that is used to estimate this number.
Currently, the algorithm does not consider the case that the key range used as a parameter might be generally of different size than the rest of the region.
The values computed here should be cached so that in high qps workloads the nn is not overwhelmed. Could be done in load(); Synchronized to make sure that only one thread at a time is using the htable.
startRowKey | First row key in the range |
endRowKey | Last row key in the range |
Definition at line 488 of file HBaseTable.java.
References com.cloudera.impala.catalog.HBaseTable.columnFamilies_, com.cloudera.impala.catalog.HBaseTable.DELTA_FROM_AVERAGE, com.cloudera.impala.catalog.HBaseTable.getEstimatedRowStatsForRegion(), com.cloudera.impala.catalog.HBaseTable.getHdfsSize(), com.cloudera.impala.catalog.HBaseTable.getRegionsInRange(), com.cloudera.impala.catalog.HBaseTable.hTable_, and com.cloudera.impala.catalog.HBaseTable.MIN_NUM_REGIONS_TO_CHECK.
|
inlineprivate |
Estimates the number of rows for a single region and returns a pair with the estimated row count and the estimated size in bytes per row.
Definition at line 399 of file HBaseTable.java.
References com.cloudera.impala.catalog.HBaseTable.getHdfsSize(), and com.cloudera.impala.catalog.HBaseTable.ROW_COUNT_ESTIMATE_BATCH_SIZE.
Referenced by com.cloudera.impala.catalog.HBaseTable.getEstimatedRowStats(), and com.cloudera.impala.catalog.HBaseTable.getTableStats().
|
inlineinherited |
Definition at line 343 of file Table.java.
References com.cloudera.impala.catalog.Table.db_, com.cloudera.impala.catalog.Db.getName(), and com.cloudera.impala.catalog.Table.name_.
Referenced by com.cloudera.impala.analysis.ShowPartitionsStmt.analyze(), com.cloudera.impala.analysis.ShowStatsStmt.analyze(), com.cloudera.impala.analysis.ShowFilesStmt.analyze(), com.cloudera.impala.analysis.AlterTableStmt.analyze(), com.cloudera.impala.analysis.TableRef.analyze(), com.cloudera.impala.analysis.InsertStmt.checkColumnCoverage(), com.cloudera.impala.planner.DataSourceScanNode.getNodeExplainString(), com.cloudera.impala.planner.HBaseScanNode.getNodeExplainString(), com.cloudera.impala.analysis.Analyzer.getTable(), com.cloudera.impala.catalog.HdfsTable.load(), com.cloudera.impala.catalog.Table.loadAllColumnStats(), com.cloudera.impala.catalog.HdfsTable.loadColumns(), com.cloudera.impala.catalog.HdfsTable.loadDiskIds(), and com.cloudera.impala.analysis.InsertStmt.setTargetTable().
|
inlinestatic |
Definition at line 594 of file HBaseTable.java.
References com.cloudera.impala.catalog.HBaseTable.hbaseConf_.
|
inlineprivate |
Definition at line 377 of file HBaseTable.java.
References com.cloudera.impala.catalog.HBaseTable.DEFAULT_PREFIX.
Referenced by com.cloudera.impala.catalog.CatalogTest.checkHBaseTableCols(), com.cloudera.impala.planner.HBaseScanNode.computeScanRangeLocations(), and com.cloudera.impala.planner.HBaseScanNode.toThrift().
|
inline |
Definition at line 586 of file HBaseTable.java.
References com.cloudera.impala.catalog.HBaseTable.hbaseTableName_.
Referenced by com.cloudera.impala.catalog.HBaseTable.load(), and com.cloudera.impala.catalog.HBaseTable.loadFromThrift().
|
inline |
Returns the Hdfs size of the given region in bytes. NULL can be passed as a parameter to retrieve the size of the complete table.
Definition at line 545 of file HBaseTable.java.
References com.cloudera.impala.catalog.HBaseTable.getRootDir(), com.cloudera.impala.catalog.HBaseTable.hbaseConf_, and com.cloudera.impala.catalog.HBaseTable.hbaseTableName_.
Referenced by com.cloudera.impala.catalog.HBaseTable.getEstimatedRowStats(), com.cloudera.impala.catalog.HBaseTable.getEstimatedRowStatsForRegion(), and com.cloudera.impala.catalog.HBaseTable.getTableStats().
|
inline |
Definition at line 590 of file HBaseTable.java.
References com.cloudera.impala.catalog.HBaseTable.hTable_.
|
inlineinherited |
Definition at line 403 of file Table.java.
References com.cloudera.impala.catalog.Table.id_.
Referenced by com.cloudera.impala.planner.HBaseTableSink.toThrift(), and com.cloudera.impala.planner.HdfsTableSink.toThrift().
|
inlineinherited |
Returns the metastore.api.Table object this Table was created from. Returns null if the derived Table object was not created from a metastore Table (ex. InlineViews).
Definition at line 398 of file Table.java.
References com.cloudera.impala.catalog.Table.msTable_.
Referenced by com.cloudera.impala.catalog.HdfsTable.getFirstLocationWithoutWriteAccess(), com.cloudera.impala.catalog.HdfsTable.getPartitionFromThriftPartitionSpec(), com.cloudera.impala.catalog.HdfsTable.getTableStats(), com.cloudera.impala.catalog.View.init(), com.cloudera.impala.catalog.DataSourceTable.load(), com.cloudera.impala.catalog.HBaseTable.load(), com.cloudera.impala.catalog.HdfsTable.load(), com.cloudera.impala.catalog.HBaseTable.loadFromThrift(), com.cloudera.impala.catalog.HdfsTable.loadFromThrift(), and com.cloudera.impala.catalog.Table.toThrift().
|
inlineinherited |
Implements com.cloudera.impala.catalog.CatalogObject.
Definition at line 342 of file Table.java.
References com.cloudera.impala.catalog.Table.name_.
Referenced by com.cloudera.impala.service.CatalogOpExecutor.alterTableUpdateStats(), com.cloudera.impala.catalog.CatalogTest.checkTableCols(), com.cloudera.impala.service.CatalogOpExecutor.createHiveColStats(), com.cloudera.impala.catalog.HdfsTable.createPartition(), com.cloudera.impala.catalog.HdfsPartition.fromThrift(), com.cloudera.impala.analysis.Analyzer.getTable(), com.cloudera.impala.analysis.InlineViewRef.InlineViewRef(), com.cloudera.impala.catalog.Table.parseColumnType(), com.cloudera.impala.analysis.InsertStmt.setTargetTable(), com.cloudera.impala.analysis.ShowStatsStmt.toThrift(), com.cloudera.impala.analysis.ComputeStatsStmt.toThrift(), com.cloudera.impala.service.CatalogOpExecutor.updateCatalog(), and com.cloudera.impala.analysis.WithClause.WithClause().
|
inlineinherited |
Returns the list of all columns excluding any partition columns.
Definition at line 385 of file Table.java.
References com.cloudera.impala.catalog.Table.numClusteringCols_.
Referenced by com.cloudera.impala.analysis.ComputeStatsStmt.analyze(), and com.cloudera.impala.catalog.Table.getColumnsInHiveOrder().
|
inlineinherited |
Definition at line 402 of file Table.java.
References com.cloudera.impala.catalog.Table.numClusteringCols_.
Referenced by com.cloudera.impala.analysis.ShowPartitionsStmt.analyze(), com.cloudera.impala.analysis.ComputeStatsStmt.analyze(), com.cloudera.impala.catalog.CatalogTest.checkTableCols(), com.cloudera.impala.service.CatalogOpExecutor.dropTableOrView(), com.cloudera.impala.analysis.ComputeStatsStmt.getBaseColumnStatsQuerySelectList(), com.cloudera.impala.planner.HdfsScanNode.getNodeExplainString(), com.cloudera.impala.catalog.HdfsTable.getNonPartitionFieldSchemas(), com.cloudera.impala.planner.HdfsScanNode.prunePartitions(), and com.cloudera.impala.service.CatalogOpExecutor.updateCatalog().
|
inline |
Definition at line 599 of file HBaseTable.java.
|
inlineinherited |
Definition at line 404 of file Table.java.
References com.cloudera.impala.catalog.Table.numRows_.
Referenced by com.cloudera.impala.analysis.IsNullPredicate.analyze().
|
inlineinherited |
Definition at line 348 of file Table.java.
References com.cloudera.impala.catalog.Table.owner_.
|
inlinestatic |
This is copied from org.apache.hadoop.hbase.client.HTable. The only difference is that it does not use cache when calling getRegionLocation. TODO: Remove this function and use HTable.getRegionsInRange when the non-cache version has been ported to CDH (DISTRO-477). Get the corresponding regions for an arbitrary range of keys.
startRow | Starting row in range, inclusive |
endRow | Ending row in range, exclusive |
IOException | if a remote or network exception occurs |
Definition at line 650 of file HBaseTable.java.
Referenced by com.cloudera.impala.catalog.HBaseTable.getEstimatedRowStats().
|
inlinestatic |
Returns hbase's root directory: i.e. hbase.rootdir
from the given configuration as a qualified Path. Method copied from HBase FSUtils.java to avoid depending on HBase server.
Definition at line 562 of file HBaseTable.java.
Referenced by com.cloudera.impala.catalog.HBaseTable.getHdfsSize().
|
inlinestaticprotectedinherited |
Returns the value of the ROW_COUNT constant, or -1 if not found.
Definition at line 191 of file Table.java.
Referenced by com.cloudera.impala.catalog.DataSourceTable.load(), com.cloudera.impala.catalog.HBaseTable.load(), com.cloudera.impala.catalog.HdfsTable.load(), and com.cloudera.impala.catalog.HdfsTable.loadPartitions().
|
inline |
Returns the storage handler class for HBase tables read by Hive.
Definition at line 676 of file HBaseTable.java.
References com.cloudera.impala.catalog.HBaseTable.HBASE_STORAGE_HANDLER.
|
inlineinherited |
Definition at line 344 of file Table.java.
References com.cloudera.impala.catalog.Table.db_, com.cloudera.impala.catalog.Db.getName(), and com.cloudera.impala.catalog.Table.name_.
Referenced by com.cloudera.impala.analysis.ComputeStatsStmt.analyze(), com.cloudera.impala.service.CatalogOpExecutor.dropStats(), and com.cloudera.impala.analysis.InlineViewRef.InlineViewRef().
|
inline |
Returns statistics on this table as a tabular result set. Used for the SHOW TABLE STATS statement. The schema of the returned TResultSet is set inside this method.
Definition at line 685 of file HBaseTable.java.
References com.cloudera.impala.catalog.Type.BIGINT, com.cloudera.impala.catalog.HBaseTable.getEstimatedRowStatsForRegion(), com.cloudera.impala.catalog.HBaseTable.getHdfsSize(), com.cloudera.impala.catalog.HBaseTable.hTable_, com.cloudera.impala.catalog.Type.STRING, and com.cloudera.impala.catalog.ScalarType.toThrift().
|
inlineprivate |
Definition at line 617 of file HBaseTable.java.
References com.cloudera.impala.catalog.HBaseColumn.getColumnQualifier(), com.cloudera.impala.catalog.Table.getColumns(), and com.cloudera.impala.catalog.HBaseTable.hbaseTableName_.
Referenced by com.cloudera.impala.catalog.HBaseTable.toThrift(), and com.cloudera.impala.catalog.HBaseTable.toThriftDescriptor().
|
inlineinherited |
Definition at line 405 of file Table.java.
References com.cloudera.impala.catalog.Table.type_.
Referenced by com.cloudera.impala.catalog.HdfsTable.load().
|
inlinestatic |
Returns true if the given Metastore Table represents an HBase table. Versions of Hive/HBase are inconsistent which HBase related fields are set (e.g., HIVE-6548 changed the input format to null). For maximum compatibility consider all known fields that indicate an HBase table.
Definition at line 739 of file HBaseTable.java.
References com.cloudera.impala.catalog.HBaseTable.HBASE_INPUT_FORMAT, com.cloudera.impala.catalog.HBaseTable.HBASE_SERIALIZATION_LIB, and com.cloudera.impala.catalog.HBaseTable.HBASE_STORAGE_HANDLER.
Referenced by com.cloudera.impala.catalog.Table.fromMetastoreTable().
|
inlineinherited |
Implements com.cloudera.impala.catalog.CatalogObject.
Definition at line 416 of file Table.java.
Referenced by com.cloudera.impala.service.CatalogOpExecutor.getExistingTable(), com.cloudera.impala.service.Frontend.getMissingTbls(), com.cloudera.impala.catalog.CatalogServiceCatalog.getOrLoadTable(), com.cloudera.impala.testutil.ImpaladTestCatalog.getTable(), com.cloudera.impala.catalog.ImpaladCatalog.getTable(), and com.cloudera.impala.analysis.Analyzer.getTable().
|
inline |
For hbase tables, we can support tables with columns we don't understand at all (e.g. map) as long as the user does not select those. This is in contrast to hdfs tables since we typically need to understand all columns to make sense of the file at all.
Definition at line 266 of file HBaseTable.java.
References com.cloudera.impala.catalog.Table.addColumn(), com.cloudera.impala.catalog.Table.clearColumns(), com.cloudera.impala.catalog.HBaseTable.columnFamilies_, com.cloudera.impala.catalog.HBaseColumn.getColumnFamily(), com.cloudera.impala.catalog.HBaseTable.getHBaseTableName(), com.cloudera.impala.catalog.Table.getMetaStoreTable(), com.cloudera.impala.catalog.Table.getRowCount(), com.cloudera.impala.catalog.HBaseTable.hbaseConf_, com.cloudera.impala.catalog.HBaseTable.hbaseTableName_, com.cloudera.impala.catalog.HBaseTable.hTable_, com.cloudera.impala.catalog.Type.INVALID, com.cloudera.impala.catalog.Table.loadAllColumnStats(), com.cloudera.impala.catalog.Table.name_, com.cloudera.impala.catalog.Table.numClusteringCols_, com.cloudera.impala.catalog.Table.numRows_, com.cloudera.impala.catalog.HBaseTable.parseColumnMapping(), com.cloudera.impala.catalog.Table.parseColumnType(), and com.cloudera.impala.catalog.HBaseTable.ROW_KEY_COLUMN_FAMILY.
|
inlineprotectedinherited |
Loads column statistics for all columns in this table from the Hive metastore. Any errors are logged and ignored, since the absence of column stats is not critical to the correctness of the system.
Definition at line 155 of file Table.java.
References com.cloudera.impala.catalog.Table.getColumn(), com.cloudera.impala.catalog.Table.getColumnNamesWithHmsStats(), com.cloudera.impala.catalog.Table.getFullName(), com.cloudera.impala.catalog.Column.getType(), com.cloudera.impala.catalog.ColumnStats.isSupportedColType(), com.cloudera.impala.catalog.Table.name_, and com.cloudera.impala.catalog.Column.updateStats().
Referenced by com.cloudera.impala.catalog.HBaseTable.load(), and com.cloudera.impala.catalog.HdfsTable.loadColumns().
|
inlineprotected |
Definition at line 364 of file HBaseTable.java.
References com.cloudera.impala.catalog.HBaseTable.columnFamilies_, com.cloudera.impala.catalog.HBaseTable.getHBaseTableName(), com.cloudera.impala.catalog.Table.getMetaStoreTable(), com.cloudera.impala.catalog.HBaseTable.hbaseConf_, com.cloudera.impala.catalog.HBaseTable.hbaseTableName_, com.cloudera.impala.catalog.HBaseTable.hTable_, and com.cloudera.impala.catalog.Table.name_.
|
inlineprivate |
Definition at line 137 of file HBaseTable.java.
References com.cloudera.impala.catalog.HBaseTable.supportsBinaryEncoding().
Referenced by com.cloudera.impala.catalog.HBaseTable.load().
|
inlineprotectedinherited |
Gets the ColumnType from the given FieldSchema by using Impala's SqlParser. Throws a TableLoadingException if the FieldSchema could not be parsed. The type can either be:
Definition at line 331 of file Table.java.
References com.cloudera.impala.catalog.Table.getName().
Referenced by com.cloudera.impala.catalog.View.load(), com.cloudera.impala.catalog.HBaseTable.load(), com.cloudera.impala.catalog.DataSourceTable.loadColumns(), com.cloudera.impala.catalog.HdfsTable.loadColumns(), and com.cloudera.impala.catalog.HBaseTable.supportsBinaryEncoding().
|
inlineinherited |
Implements com.cloudera.impala.catalog.CatalogObject.
Definition at line 411 of file Table.java.
References com.cloudera.impala.catalog.Table.catalogVersion_.
|
inlineprivate |
Definition at line 248 of file HBaseTable.java.
References com.cloudera.impala.catalog.Type.isIntegerType(), and com.cloudera.impala.catalog.Table.parseColumnType().
Referenced by com.cloudera.impala.catalog.HBaseTable.parseColumnMapping().
|
inlineinherited |
Definition at line 314 of file Table.java.
References com.cloudera.impala.catalog.Table.getCatalogObjectType(), com.cloudera.impala.catalog.Table.getCatalogVersion(), and com.cloudera.impala.catalog.Table.toThrift().
|
inline |
Definition at line 610 of file HBaseTable.java.
References com.cloudera.impala.catalog.HBaseTable.getTHBaseTable().
|
inline |
Definition at line 577 of file HBaseTable.java.
References com.cloudera.impala.catalog.Table.db_, com.cloudera.impala.catalog.Table.getColumnNames(), com.cloudera.impala.catalog.Table.getColumns(), com.cloudera.impala.catalog.Db.getName(), com.cloudera.impala.catalog.HBaseTable.getTHBaseTable(), com.cloudera.impala.catalog.HBaseTable.hbaseTableName_, com.cloudera.impala.catalog.Table.id_, and com.cloudera.impala.catalog.Table.numClusteringCols_.
|
inlineinherited |
Updates the lastDdlTime for this Table, if the new value is greater than the existing value. Does nothing if the new value is less than or equal to the existing value.
Definition at line 132 of file Table.java.
References com.cloudera.impala.catalog.Table.lastDdlTime_.
|
inlineinherited |
Checks preconditions for this table to function as expected. Currently only checks that all entries in colsByName_ use lower case keys.
Definition at line 279 of file Table.java.
References com.cloudera.impala.catalog.Table.colsByName_.
|
protectedinherited |
Definition at line 66 of file Table.java.
Referenced by com.cloudera.impala.catalog.HdfsTable.getFirstLocationWithoutWriteAccess(), com.cloudera.impala.catalog.HdfsTable.hasWriteAccess(), com.cloudera.impala.catalog.Table.loadFromThrift(), com.cloudera.impala.catalog.HdfsTable.loadPartitions(), and com.cloudera.impala.catalog.Table.toThrift().
|
private |
Definition at line 121 of file HBaseTable.java.
Referenced by com.cloudera.impala.catalog.HBaseTable.getEstimatedRowStats(), com.cloudera.impala.catalog.HBaseTable.load(), and com.cloudera.impala.catalog.HBaseTable.loadFromThrift().
|
protectedinherited |
Definition at line 61 of file Table.java.
Referenced by com.cloudera.impala.catalog.Table.getDb(), com.cloudera.impala.catalog.Table.getFullName(), com.cloudera.impala.catalog.Table.getTableName(), com.cloudera.impala.catalog.View.init(), com.cloudera.impala.catalog.HdfsTable.load(), com.cloudera.impala.catalog.Table.Table(), com.cloudera.impala.catalog.IncompleteTable.toThrift(), com.cloudera.impala.catalog.Table.toThrift(), com.cloudera.impala.catalog.DataSourceTable.toThriftDescriptor(), com.cloudera.impala.catalog.HBaseTable.toThriftDescriptor(), and com.cloudera.impala.catalog.HdfsTable.toThriftDescriptor().
|
static |
Definition at line 84 of file HBaseTable.java.
Referenced by com.cloudera.impala.catalog.HBaseTable.getHBaseTableName().
|
staticprivate |
Definition at line 79 of file HBaseTable.java.
Referenced by com.cloudera.impala.catalog.HBaseTable.getEstimatedRowStats().
|
protectedinherited |
Definition at line 65 of file Table.java.
Referenced by com.cloudera.impala.catalog.HdfsTable.getFieldSchemas(), com.cloudera.impala.catalog.HdfsTable.loadColumns(), and com.cloudera.impala.catalog.Table.loadFromThrift().
|
staticprivate |
Definition at line 101 of file HBaseTable.java.
Referenced by com.cloudera.impala.catalog.HBaseTable.isHBaseTable().
|
staticprivate |
Definition at line 105 of file HBaseTable.java.
Referenced by com.cloudera.impala.catalog.HBaseTable.isHBaseTable().
|
staticprivate |
Definition at line 109 of file HBaseTable.java.
Referenced by com.cloudera.impala.catalog.HBaseTable.getStorageHandlerClassName(), and com.cloudera.impala.catalog.HBaseTable.isHBaseTable().
|
staticprivate |
|
protected |
Definition at line 98 of file HBaseTable.java.
Referenced by com.cloudera.impala.catalog.HBaseTable.getHBaseTableName(), com.cloudera.impala.catalog.HBaseTable.getHdfsSize(), com.cloudera.impala.catalog.HBaseTable.getTHBaseTable(), com.cloudera.impala.catalog.HBaseTable.load(), com.cloudera.impala.catalog.HBaseTable.loadFromThrift(), and com.cloudera.impala.catalog.HBaseTable.toThriftDescriptor().
|
private |
Definition at line 118 of file HBaseTable.java.
Referenced by com.cloudera.impala.catalog.HBaseTable.getEstimatedRowStats(), com.cloudera.impala.catalog.HBaseTable.getHTable(), com.cloudera.impala.catalog.HBaseTable.getTableStats(), com.cloudera.impala.catalog.HBaseTable.load(), and com.cloudera.impala.catalog.HBaseTable.loadFromThrift().
|
protectedinherited |
Definition at line 60 of file Table.java.
Referenced by com.cloudera.impala.catalog.Table.getId(), com.cloudera.impala.catalog.Table.Table(), com.cloudera.impala.catalog.DataSourceTable.toThriftDescriptor(), com.cloudera.impala.catalog.HBaseTable.toThriftDescriptor(), and com.cloudera.impala.catalog.HdfsTable.toThriftDescriptor().
|
protectedinherited |
Definition at line 85 of file Table.java.
Referenced by com.cloudera.impala.catalog.HdfsTable.load(), com.cloudera.impala.catalog.Table.Table(), and com.cloudera.impala.catalog.Table.updateLastDdlTime().
|
staticprivate |
Definition at line 81 of file HBaseTable.java.
|
staticprivate |
Definition at line 90 of file HBaseTable.java.
Referenced by com.cloudera.impala.catalog.HBaseTable.getEstimatedRowStats().
|
protectedinherited |
Definition at line 58 of file Table.java.
Referenced by com.cloudera.impala.catalog.Table.getMetaStoreTable(), and com.cloudera.impala.catalog.Table.Table().
|
protectedinherited |
Definition at line 62 of file Table.java.
Referenced by com.cloudera.impala.catalog.Table.getFullName(), com.cloudera.impala.catalog.Table.getName(), com.cloudera.impala.catalog.DataSourceTable.getRequiredTableProperty(), com.cloudera.impala.catalog.Table.getTableName(), com.cloudera.impala.catalog.View.init(), com.cloudera.impala.catalog.View.load(), com.cloudera.impala.catalog.DataSourceTable.load(), com.cloudera.impala.catalog.HBaseTable.load(), com.cloudera.impala.catalog.HdfsTable.load(), com.cloudera.impala.catalog.Table.loadAllColumnStats(), com.cloudera.impala.catalog.HdfsTable.loadBlockMetadata(), com.cloudera.impala.catalog.HBaseTable.loadFromThrift(), com.cloudera.impala.catalog.Table.Table(), com.cloudera.impala.catalog.IncompleteTable.toThrift(), com.cloudera.impala.catalog.Table.toThrift(), com.cloudera.impala.catalog.DataSourceTable.toThriftDescriptor(), and com.cloudera.impala.catalog.HdfsTable.toThriftDescriptor().
|
protectedinherited |
Definition at line 69 of file Table.java.
Referenced by com.cloudera.impala.catalog.HdfsTable.dropPartition(), com.cloudera.impala.catalog.HdfsTable.getColumnNamesWithHmsStats(), com.cloudera.impala.catalog.Table.getColumnsInHiveOrder(), com.cloudera.impala.catalog.Table.getNonClusteringColumns(), com.cloudera.impala.catalog.Table.getNumClusteringCols(), com.cloudera.impala.catalog.HdfsTable.getTableStats(), com.cloudera.impala.catalog.View.load(), com.cloudera.impala.catalog.DataSourceTable.load(), com.cloudera.impala.catalog.HBaseTable.load(), com.cloudera.impala.catalog.HdfsTable.load(), com.cloudera.impala.catalog.HdfsTable.loadColumns(), com.cloudera.impala.catalog.Table.loadFromThrift(), com.cloudera.impala.catalog.HdfsTable.resetPartitionMd(), com.cloudera.impala.catalog.Table.toThrift(), com.cloudera.impala.catalog.DataSourceTable.toThriftDescriptor(), com.cloudera.impala.catalog.HBaseTable.toThriftDescriptor(), com.cloudera.impala.catalog.HdfsTable.toThriftDescriptor(), and com.cloudera.impala.catalog.HdfsTable.updatePartitionMdAndColStats().
|
protectedinherited |
Definition at line 72 of file Table.java.
Referenced by com.cloudera.impala.catalog.Table.getNumRows(), com.cloudera.impala.catalog.DataSourceTable.getTableStats(), com.cloudera.impala.catalog.HdfsTable.getTableStats(), com.cloudera.impala.catalog.View.load(), com.cloudera.impala.catalog.DataSourceTable.load(), com.cloudera.impala.catalog.HBaseTable.load(), com.cloudera.impala.catalog.HdfsTable.load(), com.cloudera.impala.catalog.Table.loadFromThrift(), com.cloudera.impala.catalog.CatalogObjectToFromThriftTest.TestPartitionedTable(), and com.cloudera.impala.catalog.Table.toThrift().
|
protectedinherited |
Definition at line 63 of file Table.java.
Referenced by com.cloudera.impala.catalog.Table.getOwner(), and com.cloudera.impala.catalog.Table.Table().
|
static |
Definition at line 87 of file HBaseTable.java.
Referenced by com.cloudera.impala.catalog.HBaseTable.getEstimatedRowStatsForRegion().
|
staticprivate |
Definition at line 113 of file HBaseTable.java.
Referenced by com.cloudera.impala.catalog.HBaseTable.load().
|
protected |
Definition at line 94 of file HBaseTable.java.
|
staticprotectedinherited |
Definition at line 88 of file Table.java.
|
protectedinherited |
Definition at line 64 of file Table.java.
|
protectedinherited |
Definition at line 82 of file Table.java.
Referenced by com.cloudera.impala.catalog.Table.addColumn(), com.cloudera.impala.catalog.Table.clearColumns(), com.cloudera.impala.catalog.Table.getType(), and com.cloudera.impala.catalog.Table.loadFromThrift().