| Interface | Description |
|---|---|
| AlterHandler |
Interface for Alter Table and Alter Partition code
|
| FileFormatProxy |
Same as PartitionExpressionProxy, but for file format specific methods for metadata cache.
|
| HiveMetaHook |
HiveMetaHook defines notification methods which are invoked as part
of transactions against the metastore, allowing external catalogs
such as HBase to be kept in sync with Hive's metastore.
|
| HiveMetaHookLoader |
HiveMetaHookLoader is responsible for loading a
HiveMetaHook
for a given table. |
| IExtrapolatePartStatus | |
| IHMSHandler |
An interface wrapper for HMSHandler.
|
| IMetaStoreClient |
Wrapper around hive metastore thrift api
|
| IMetaStoreClient.NotificationFilter |
A filter provided by the client that determines if a given notification event should be
returned.
|
| IMetaStoreSchemaInfo |
Defines the method which must be implemented to be used using schema tool to support metastore
schema upgrades.
|
| MetadataStore | |
| MetaStoreFilterHook |
Metadata filter hook for metastore client.
|
| MetaStoreFS |
Define a set of APIs that may vary in different environments
|
| MetastoreTaskThread |
Any task that will run as a separate thread in the metastore should implement this
interface.
|
| MetaStoreThread |
A thread that runs in the metastore, separate from the threads in the thrift service.
|
| PartitionExpressionProxy |
The proxy interface that metastore uses for variety of QL operations (metastore can't depend
on QL because QL depends on metastore; creating metastore-client module would be a proper way
to solve this problem).
|
| RawStore |
| Class | Description |
|---|---|
| AcidEventListener |
It handles cleanup of dropped partition/table/database in ACID related metastore tables
|
| AggregateStatsCache | |
| AggregateStatsCache.AggrColStats | |
| ColumnType |
Constants and utility functions for column types.
|
| Deadline |
This class is used to monitor long running methods in a thread.
|
| DefaultHiveMetaHook | |
| DefaultMetaStoreFilterHookImpl |
Default no-op implementation of the MetaStoreFilterHook that returns the result as is
|
| DefaultPartitionExpressionProxy |
Default implementation of PartitionExpressionProxy.
|
| DefaultStorageSchemaReader |
Default StorageSchemaReader.
|
| FileMetadataHandler |
The base implementation of a file metadata handler for a specific file type.
|
| FileMetadataManager | |
| HiveAlterHandler |
Hive specific implementation of alter
|
| HiveMetaStore |
TODO:pc remove application logic to a separate interface.
|
| HiveMetaStore.HiveMetastoreCli |
HiveMetaStore specific CLI
|
| HiveMetaStore.HMSHandler | |
| HiveMetaStoreClient |
Hive Metastore Client.
|
| HiveMetaStoreClient.MetastoreMapIterable<K,V> | |
| HiveMetaStoreFsImpl | |
| HiveMetaStoreUtils | |
| HMSMetricsListener |
Report metrics of metadata added, deleted by this Hive Metastore.
|
| LinearExtrapolatePartStatus | |
| LockComponentBuilder |
A builder for
LockComponents |
| LockRequestBuilder |
Builder class to make constructing
LockRequest easier. |
| MaterializationsRebuildLockCleanerTask |
Cleaner for the
MaterializationsRebuildLockHandler. |
| MaterializationsRebuildLockHandler |
This is a lock handler implementation for the materializations rebuild.
|
| MetaStoreEndFunctionContext |
Base class which provides context to implementations of MetaStoreEndFunctionListener
|
| MetaStoreEndFunctionListener |
This abstract class needs to be extended to provide implementation of actions that need
to be performed when a function ends.
|
| MetaStoreEventListener |
This abstract class needs to be extended to provide implementation of actions that needs
to be performed when a particular event occurs on a metastore.
|
| MetaStoreEventListenerConstants |
Keeps a list of reserved keys used by Hive listeners when updating the ListenerEvent
parameters.
|
| MetaStoreInit |
MetaStoreInit defines functions to init/update MetaStore connection url.
|
| MetaStoreInitContext |
Base class which provides context to implementations of MetaStoreInitListener
|
| MetaStoreInitListener |
This abstract class needs to be extended to provide implementation of actions
that needs to be performed when HMSHandler is initialized
|
| MetaStoreListenerNotifier |
This class is used to notify a list of listeners about specific MetaStore events.
|
| MetaStorePreEventListener |
This abstract class needs to be extended to provide implementation of actions that needs
to be performed before a particular event occurs on a metastore.
|
| MetaStoreSchemaInfo | |
| MetaStoreSchemaInfoFactory |
Factory class implementation to create instances of IMetaStoreSchemaInfo
based on the provided configuration
|
| ObjectStore |
This class is the interface between the application logic and the database
store that contains the objects.
|
| ObjectStore.QueryWrapper |
A Autocloseable wrapper around Query class to pass the Query object to the caller and let the caller release
the resources when the QueryWrapper goes out of scope
|
| PartFilterExprUtil |
Utility functions for working with partition filter expressions
|
| PartitionDropOptions |
Class to generalize the switches for dropPartitions().
|
| RawStoreProxy | |
| ReplChangeManager | |
| ReplChangeManager.FileInfo | |
| RetryingHMSHandler | |
| RetryingMetaStoreClient |
RetryingMetaStoreClient.
|
| RuntimeStatsCleanerTask |
Metastore task to handle RuntimeStat related expiration.
|
| SerDeStorageSchemaReader | |
| SessionPropertiesListener |
It handles the changed properties in the change event.
|
| StatObjectConverter |
This class contains conversion logic that creates Thrift stat objects from
JDO stat objects and plain arrays from DirectSQL.
|
| SynchronizedMetaStoreClient |
Synchronized MetaStoreClient wrapper
|
| ThreadPool |
Utility singleton class to manage all the threads.
|
| TransactionalMetaStoreEventListener |
Special type of MetaStoreEventListener which should only be called in a transactional context
and only if the transaction is successful.
|
| TransactionalValidationListener | |
| TServerSocketKeepAlive |
TServerSocketKeepAlive - like TServerSocket, but will enable keepalive for
accepted sockets.
|
| TSetIpAddressProcessor<I extends org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface> |
TSetIpAddressProcessor passes the IP address of the Thrift client to the HMSHandler.
|
| TUGIBasedProcessor<I extends org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface> |
TUGIBasedProcessor is used in unsecure mode for thrift metastore client server communication.
|
| Warehouse |
This class represents a warehouse where data of Hive tables is stored
|
| Enum | Description |
|---|---|
| DatabaseProduct |
Database product infered via JDBC.
|
| IExtrapolatePartStatus.AggrType |
The sequence of aggregation function on colStats.
|
| IExtrapolatePartStatus.ColStatType |
The sequence of colStatTypes.
|
| ReplChangeManager.RecycleType | |
| TableType |
Typesafe enum for types of tables described by the metastore.
|
| Exception | Description |
|---|---|
| DeadlineException |
Thrown when a long running method timeout is checked.
|
| HiveMetaException | |
| IMetaStoreClient.IncompatibleMetastoreException |
| Annotation Type | Description |
|---|---|
| RawStore.CanNotRetry |
Annotation to skip retries
|
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.