Changed Classes in Hive 2.1

The following classes have changes in Hive 2.1:

Class Description

org.apache.hadoop.hive.accumulo.mr.HiveAccumuloTableOutputFormat

Output format for accumulo tables.
org.apache.hadoop.hive.cli.CliDriver CliDriver.
org.apache.hadoop.hive.cli.OptionsProcessor OptionsProcessor.
org.apache.hadoop.hive.common.CompressionUtils Contains methods used for the purposes of compression. This class should not be accessed from code run in Hadoop.
org.apache.hadoop.hive.common.FileUtils Collection of file manipulation utilities common across Hive.
org.apache.hadoop.hive.common.HiveStatsUtils HiveStatsUtils.
org.apache.hadoop.hive.common.JavaUtils Collection of Java class loading/reflection related utilities common across Hive.
org.apache.hadoop.hive.common.LogUtils Utilities common to logging operations.
org.apache.hadoop.hive.common.ObjectPair Creating pair out of templates.
org.apache.hadoop.hive.common.ServerUtils ServerUtils (specific to HiveServer version 1)
org.apache.hadoop.hive.common.StatsSetupConst Defines the constant strings used by the statistics implementation.
org.apache.hadoop.hive.common.ValidReadTxnList An implementation of org.apache.hadoop.hive.common.ValidTxnList for use by readers.
org.apache.hadoop.hive.common.cli.CommonCliOptions Reusable code for Hive Cli's.
org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream A thread-not-safe version of ByteArrayOutputStream, which removes all synchronized modifiers.
org.apache.hadoop.hive.common.type.HiveDecimal HiveDecimal.
org.apache.hadoop.hive.common.type.HiveIntervalDayTime Day-time interval type representing an offset in days/hours/minutes/seconds, with nanosecond precision.
org.apache.hadoop.hive.common.type.HiveVarchar HiveVarChar.
org.apache.hadoop.hive.conf.HiveConf Hive Configuration.
org.apache.hadoop.hive.conf.HiveConfUtil Hive Configuration utils
org.apache.hadoop.hive.contrib.serde2.MultiDelimitSerDe This SerDe allows user to use multiple characters as the field delimiter for a table.
org.apache.hadoop.hive.contrib.serde2.RegexSerDe RegexSerDe uses regular expression (regex) to serialize/deserialize.
org.apache.hadoop.hive.contrib.serde2.TypedBytesSerDe TypedBytesSerDe uses typed bytes to serialize/deserialize.
org.apache.hadoop.hive.contrib.serde2.s3.S3LogDeserializer S3LogDeserializer.
org.apache.hadoop.hive.hbase.AbstractHBaseKeyPredicateDecomposer Simple abstract class to help with creation of a DecomposedPredicate.
org.apache.hadoop.hive.hbase.CompositeHBaseKeyFactory Factory that creates composite keys.
org.apache.hadoop.hive.hbase.HBaseLazyObjectFactory

Replaces original keyOI with OI which is create by HBaseKeyFactory provided by serde property for hbase.

org.apache.hadoop.hive.hbase.HBaseSerDe HBaseSerDe can be used to serialize object into an HBase table and deserialize objects from an HBase table.
org.apache.hadoop.hive.hbase.HBaseSerDeHelper Helper class for HBaseSerDe
org.apache.hadoop.hive.hbase.HiveHBaseTableInputFormat HiveHBaseTableInputFormat implements InputFormat for HBase storage handler tables, decorating an underlying HBase TableInputFormat with extra Hive logic such as column pruning and filter pushdown.
org.apache.hadoop.hive.hbase.HiveHBaseTableOutputFormat HiveHBaseTableOutputFormat implements HiveOutputFormat for HBase tables.
org.apache.hadoop.hive.hbase.LazyHBaseCellMap LazyHBaseCellMap refines LazyMap with HBase column mapping.
org.apache.hadoop.hive.hwi.HWIContextListener After getting a contextInitialized event, this component starts an instance of the HiveSessionManager.
org.apache.hadoop.hive.hwi.HWIServer This is the entry point for HWI.
org.apache.hadoop.hive.hwi.HWISessionItem HWISessionItem can be viewed as a wrapper for a Hive shell.
org.apache.hadoop.hive.hwi.HWISessionManager HiveSessionManager is a Runnable started inside a web application context.
org.apache.hadoop.hive.metastore.Deadline Monitors long running methods in a thread.
org.apache.hadoop.hive.metastore.HiveAlterHandler Hive specific implementation of alter.
org.apache.hadoop.hive.metastore.HiveMetaStore Removes application logic to a separate interface.
org.apache.hadoop.hive.metastore.HiveMetaStoreClient Hive Metastore Client.
org.apache.hadoop.hive.metastore.HiveMetaStoreFsImpl Class to handle methods for filesystem and data related to metastore.
org.apache.hadoop.hive.metastore.LockComponentBuilder A builder for LockComponents.
org.apache.hadoop.hive.metastore.LockRequestBuilder Builder class to make constructing LockRequest easier.
org.apache.hadoop.hive.metastore.MetaStoreSchemaInfo Information about metastore schemas stored in database.
org.apache.hadoop.hive.metastore.MetaStoreUtils Utilities to handle metastore data.
org.apache.hadoop.hive.metastore.ObjectStore Interface between the application logic and the database store that contains the objects.
org.apache.hadoop.hive.metastore.PartitionDropOptions Generalizes the switches for dropPartitions().
org.apache.hadoop.hive.metastore.RetryingHMSHandler Handler for hive metastore.
org.apache.hadoop.hive.metastore.RetryingMetaStoreClient RetryingMetaStoreClient.
org.apache.hadoop.hive.metastore.StatObjectConverter Contains conversion logic that creates Thrift stat objects from JDO stat objects and plain arrays from DirectSQL.
org.apache.hadoop.hive.metastore.Warehouse Represents a warehouse where data of Hive tables is stored.
org.apache.hadoop.hive.metastore.api.AbortTxnRequest Aborting transaction request.
org.apache.hadoop.hive.metastore.api.AddDynamicPartitions Adding dynamic partitions.
org.apache.hadoop.hive.metastore.api.AddPartitionsRequest Adding partition request.
org.apache.hadoop.hive.metastore.api.AddPartitionsResult Adding partition result.
org.apache.hadoop.hive.metastore.api.AggrStats Aggregation statistics.
org.apache.hadoop.hive.metastore.api.BinaryColumnStatsData Binary column statistics data.
org.apache.hadoop.hive.metastore.api.BooleanColumnStatsData Boolean column statistics data.
org.apache.hadoop.hive.metastore.api.CheckLockRequest Checking request on acquiring lock.
org.apache.hadoop.hive.metastore.api.ColumnStatistics Column statistics class.
org.apache.hadoop.hive.metastore.api.ColumnStatisticsDesc Column statistics description.
org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj Column statistics object.
org.apache.hadoop.hive.metastore.api.CommitTxnRequest Commit transaction request.
org.apache.hadoop.hive.metastore.api.CompactionRequest Compaction request.
org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId Current notification event ID.
org.apache.hadoop.hive.metastore.api.Database Class that describes database.
org.apache.hadoop.hive.metastore.api.Date Date class.
org.apache.hadoop.hive.metastore.api.DateColumnStatsData Date column statistics data.
org.apache.hadoop.hive.metastore.api.Decimal Handling decimal type.
org.apache.hadoop.hive.metastore.api.DecimalColumnStatsData Decimal column statistics data.
org.apache.hadoop.hive.metastore.api.DoubleColumnStatsData Double column statistics data.
org.apache.hadoop.hive.metastore.api.DropPartitionsExpr Drop partitions expression.
org.apache.hadoop.hive.metastore.api.DropPartitionsRequest Drop partitions request.
org.apache.hadoop.hive.metastore.api.DropPartitionsResult Drop partitions result.
org.apache.hadoop.hive.metastore.api.EnvironmentContext Environment context structure.
org.apache.hadoop.hive.metastore.api.FieldSchema Field schema structure.
org.apache.hadoop.hive.metastore.api.FireEventRequest Fire event request.
org.apache.hadoop.hive.metastore.api.FireEventResponse Fire event response.
org.apache.hadoop.hive.metastore.api.Function Function structure.
org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse Getter for open transactions information about response.
org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse Getter for open transactions response.
org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest Getting request for principals in role.
org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse Getting response for principals in role.
org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest Getting request for granting role for principal.
org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse Getting response for granting role for principal.
org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest Request for revoking granted privilege.
org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse Response for revoking granted privilege.
org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest Request for revoking granted role.
org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse Response for revoking granted role.
org.apache.hadoop.hive.metastore.api.HeartbeatRequest Request for heartbeat.
org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest Request for transaction range request.
org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse Response for transaction range response.
org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege Description of privileges for hive object.
org.apache.hadoop.hive.metastore.api.HiveObjectRef Hive object reference.
org.apache.hadoop.hive.metastore.api.Index Description of index.
org.apache.hadoop.hive.metastore.api.InsertEventRequestData Class to handle data about insert event on request.
org.apache.hadoop.hive.metastore.api.LockComponent Description of lock component.
org.apache.hadoop.hive.metastore.api.LockRequest Description of lock request.
org.apache.hadoop.hive.metastore.api.LockResponse Description of lock response.
org.apache.hadoop.hive.metastore.api.LongColumnStatsData Description of long column statistics data.
org.apache.hadoop.hive.metastore.api.NotificationEvent Description of notification event.
org.apache.hadoop.hive.metastore.api.NotificationEventRequest Description of notification event on request.
org.apache.hadoop.hive.metastore.api.NotificationEventResponse Description of notification event on response.
org.apache.hadoop.hive.metastore.api.OpenTxnRequest Description of open transactions on request.
org.apache.hadoop.hive.metastore.api.OpenTxnsResponse Description of open transactions on response.
org.apache.hadoop.hive.metastore.api.Order Description of order.
org.apache.hadoop.hive.metastore.api.Partition Description of partition.
org.apache.hadoop.hive.metastore.api.PartitionListComposingSpec Description of partition list composing specification.
org.apache.hadoop.hive.metastore.api.PartitionSpec Description of partition specification.
org.apache.hadoop.hive.metastore.api.PartitionSpecWithSharedSD Description of partition specification with shared sd.
org.apache.hadoop.hive.metastore.api.PartitionWithoutSD Description of partition without sd.
org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest Description of partitions by expression request.
org.apache.hadoop.hive.metastore.api.PartitionsByExprResult Description of partitions by expression result.
org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest Description of partition statistics request.
org.apache.hadoop.hive.metastore.api.PartitionsStatsResult Description of partitions statistics result.
org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet Description of setting principal privilege.
org.apache.hadoop.hive.metastore.api.PrivilegeBag Description of privilege bag.
org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo Description of granted privilege info.
org.apache.hadoop.hive.metastore.api.ResourceUri Description of resource URI.
org.apache.hadoop.hive.metastore.api.Role Description of role.
org.apache.hadoop.hive.metastore.api.RolePrincipalGrant Description of granted principal role.
org.apache.hadoop.hive.metastore.api.Schema Description of schema.
org.apache.hadoop.hive.metastore.api.SerDeInfo Description of serializer deserializer information.
org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest Description of setting partition statistics on request.
org.apache.hadoop.hive.metastore.api.ShowCompactRequest Show compaction on request.
org.apache.hadoop.hive.metastore.api.ShowCompactResponse Show compaction on response.
org.apache.hadoop.hive.metastore.api.ShowCompactResponseElement Show compaction response element.
org.apache.hadoop.hive.metastore.api.ShowLocksRequest Show locks on request.
org.apache.hadoop.hive.metastore.api.ShowLocksResponse Show locks on response.
org.apache.hadoop.hive.metastore.api.ShowLocksResponseElement Show locks response element.
org.apache.hadoop.hive.metastore.api.SkewedInfo Description for skewed information.
org.apache.hadoop.hive.metastore.api.StorageDescriptor Description for storage descriptor.
org.apache.hadoop.hive.metastore.api.StringColumnStatsData Description for string column statistics data.
org.apache.hadoop.hive.metastore.api.Table Description for data.
org.apache.hadoop.hive.metastore.api.TableStatsRequest Description for table statistics request.
org.apache.hadoop.hive.metastore.api.TableStatsResult Description for table statistics result.
org.apache.hadoop.hive.metastore.api.AlreadyExistsException Custom exception to handle already exists error.
org.apache.hadoop.hive.metastore.api.ConfigValSecurityException Custom exception to handle configuration value security error.
org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException Custom exception to handle index already exists error.
org.apache.hadoop.hive.metastore.api.InvalidInputException Custom exception for invalid input error.
org.apache.hadoop.hive.metastore.api.InvalidObjectException Custom exception for invalid object error.
org.apache.hadoop.hive.metastore.api.InvalidOperationException Custom exception for invalid operation error.
org.apache.hadoop.hive.metastore.api.InvalidPartitionException Custom exception for invalid partition error.
org.apache.hadoop.hive.metastore.api.MetaException Custom exception for metastore related error.
org.apache.hadoop.hive.metastore.api.NoSuchLockException Custom exception in case of invalid lock.
org.apache.hadoop.hive.metastore.api.NoSuchObjectException Custom exception in case of invalid object.
org.apache.hadoop.hive.metastore.api.NoSuchTxnException Custom exception in case of invalid transaction.
org.apache.hadoop.hive.metastore.api.TxnAbortedException Custom exception in case of aborted transaction.
org.apache.hadoop.hive.metastore.api.TxnOpenException Custom exception in case of not close transaction.
org.apache.hadoop.hive.metastore.api.UnknownDBException Custom exception in case of unknown database.
org.apache.hadoop.hive.metastore.api.UnknownPartitionException Custom exception in case of unknown partition.
org.apache.hadoop.hive.metastore.api.UnknownTableException Custom partition in case of unknown table.
org.apache.hadoop.hive.metastore.events.EventCleanerTask Cleaning tasks from event table.
org.apache.hadoop.hive.metastore.parser.ExpressionTree Represents the filter as a binary tree.
org.apache.hadoop.hive.metastore.txn.CompactionInfo Information on a possible or running compaction.
org.apache.hadoop.hive.metastore.txn.CompactionInfo Utility methods for creating and destroying txn database/schema, plus methods for querying against metastore tables.
org.apache.hadoop.hive.ql.Context Context for Semantic Analyzers.
org.apache.hadoop.hive.ql.Driver Driver to process commands on cluster.
org.apache.hadoop.hive.ql.QueryPlan QueryPlan can be serialized to disk to restart/resume the progress of it in the future, either within or outside of the current JVM.
org.apache.hadoop.hive.ql.QueryProperties QueryProperties.
org.apache.hadoop.hive.ql.exec.AbstractFileMergeOperator Fast file merge operator for ORC and RCfile.
org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator Class to handle join input’s join keys.
org.apache.hadoop.hive.ql.exec.AppMasterEventOperator AppMasterEventOperator sends any rows it receives to the Tez AM.
org.apache.hadoop.hive.ql.exec.AutoProgressor AutoProgressor periodically sends updates to the job tracker so that it doesn't consider this task attempt dead if there is a long period of inactivity.
org.apache.hadoop.hive.ql.exec.CollectOperator Buffers rows emitted by other operators.
org.apache.hadoop.hive.ql.exec.ColumnStatsTask ColumnStatsTask implementation.
org.apache.hadoop.hive.ql.exec.ColumnStatsUpdateTask ColumnStatsUpdateTask implementation.
org.apache.hadoop.hive.ql.exec.CommonJoinOperator Join operator implementation.
org.apache.hadoop.hive.ql.exec.CommonMergeJoinOperator

Consolidate the join algorithms to either hash based joins (MapJoinOperator) or sort-merge based joins, this operator is being introduced.

org.apache.hadoop.hive.ql.exec.ConditionalTask Conditional Task implementation.
org.apache.hadoop.hive.ql.exec.DDLTask DDLTask implementation.
org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher Finding right bucket.
org.apache.hadoop.hive.ql.exec.DemuxOperator DemuxOperator is an operator used by MapReduce Jobs optimized by CorrelationOptimizer.
org.apache.hadoop.hive.ql.exec.DummyStoreOperator For SortMerge joins, this is a dummy operator, which stores the row for the small table before it reaches the sort merge join operator.
org.apache.hadoop.hive.ql.exec.ExplainTask ExplainTask implementation.
org.apache.hadoop.hive.ql.exec.FetchOperator FetchTask implementation.
org.apache.hadoop.hive.ql.exec.FetchTask FetchTask implementation.
org.apache.hadoop.hive.ql.exec.FileSinkOperator File Sink operator implementation.
org.apache.hadoop.hive.ql.exec.FilterOperator Filter operator implementation.
org.apache.hadoop.hive.ql.exec.ForwardOperator Forward Operator Just forwards.
org.apache.hadoop.hive.ql.exec.FunctionRegistry FunctionRegistry.
org.apache.hadoop.hive.ql.exec.FunctionTask FunctionTask.
org.apache.hadoop.hive.ql.exec.GroupByOperator GroupBy operator implementation.
org.apache.hadoop.hive.ql.exec.HashTableDummyOperator Hash table operator implementation.
org.apache.hadoop.hive.ql.exec.HashTableSinkOperator Hash table sink operator implementation.
org.apache.hadoop.hive.ql.exec.JoinOperator Join operator implementation.
org.apache.hadoop.hive.ql.exec.LateralViewForwardOperator LateralViewForwardOperator.
org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator The lateral view join operator is used for FROM src LATERAL VIEW udtf()...
org.apache.hadoop.hive.ql.exec.LimitOperator Limit operator implementation Limits the number of rows to be passed on.
org.apache.hadoop.hive.ql.exec.ListSinkOperator For fetch task with operator tree, row read from FetchOperator is processed via operator tree and finally arrives to this operator.
org.apache.hadoop.hive.ql.exec.MapJoinOperator Map side Join operator implementation.
org.apache.hadoop.hive.ql.exec.MapOperator Map operator.
org.apache.hadoop.hive.ql.exec.MapredContext Runtime context of MapredTask providing additional information to GenericUDF
org.apache.hadoop.hive.ql.exec.MoveTask MoveTask implementation.
org.apache.hadoop.hive.ql.exec.MuxOperator MuxOperator is used in the Reduce side of MapReduce jobs optimized by Correlation Optimizer.
org.apache.hadoop.hive.ql.exec.ObjectCacheFactory ObjectCacheFactory returns the appropriate cache depending on settings in the hive conf.
org.apache.hadoop.hive.ql.exec.Operator Base operator implementation.
org.apache.hadoop.hive.ql.exec.OperatorFactory OperatorFactory.
org.apache.hadoop.hive.ql.exec.OperatorUtils Utilities to handle operators.
org.apache.hadoop.hive.ql.exec.OrcFileMergeOperator Fast file merge operator for ORC files.
org.apache.hadoop.hive.ql.exec.PTFOperator Class to handle partitioned table functions operators.
org.apache.hadoop.hive.ql.exec.PTFPartition

Represents a collection of rows that is acted upon by a TableFunction or a WindowFunction.

org.apache.hadoop.hive.ql.exec.PTFRollingPartition Represents a collection of rows that is acted upon by a TableFunction or a WindowFunction.

org.apache.hadoop.hive.ql.exec.PTFUtils

Utilities to handle partitioned table functions.
org.apache.hadoop.hive.ql.exec.PartitionKeySampler Class to handle partition key sampler.
org.apache.hadoop.hive.ql.exec.RCFileMergeOperator Fast file merge operator for RC files.
org.apache.hadoop.hive.ql.exec.ReduceSinkOperator Reduce Sink Operator sends output to the reduce stage.
org.apache.hadoop.hive.ql.exec.Registry Function registry.
org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator Sorted Merge Map Join Operator.
org.apache.hadoop.hive.ql.exec.ScriptOperator ScriptOperator.
org.apache.hadoop.hive.ql.exec.SelectOperator Select operator implementation.
org.apache.hadoop.hive.ql.exec.SkewJoinHandler At runtime in Join, output big keys in one table into one corresponding directories, and all same keys in other tables into different dirs (one for each table).
org.apache.hadoop.hive.ql.exec.SparkHashTableSinkOperator Operator for spark hashtable sink.
org.apache.hadoop.hive.ql.exec.StatsNoJobTask StatsNoJobTask is used in cases where stats collection is the only task for the given query (no parent MR or Tez job).
org.apache.hadoop.hive.ql.exec.TableScanOperator Table Scan Operator If the data is coming from the map-reduce framework, just forward it.
org.apache.hadoop.hive.ql.exec.Task Task implementation.
org.apache.hadoop.hive.ql.exec.TaskResult TaskResult implementation.
org.apache.hadoop.hive.ql.exec.TemporaryHashSinkOperator Operator temporary hash sink.
org.apache.hadoop.hive.ql.exec.TerminalOperator Terminal Operator Base Class.
org.apache.hadoop.hive.ql.exec.TezDummyStoreOperator A dummy store operator same as the dummy store operator but for tez.
org.apache.hadoop.hive.ql.exec.TopNHash Stores binary key/value in sorted manner to get top-n key/value TODO: rename to TopNHeap?
org.apache.hadoop.hive.ql.exec.UDTFOperator UDTFOperator.
org.apache.hadoop.hive.ql.exec.UnionOperator Union Operator Just forwards.
org.apache.hadoop.hive.ql.exec.Utilities Utilities.
org.apache.hadoop.hive.ql.exec.mr.ExecDriver ExecDriver is the central class in co-ordinating execution of any map-reduce task.
org.apache.hadoop.hive.ql.exec.mr.ExecMapper ExecMapper is the generic Map class for Hive.
org.apache.hadoop.hive.ql.exec.mr.ExecMapperContext ExecMapperContext is the generic Map context class for Hive.
org.apache.hadoop.hive.ql.exec.mr.HadoopJobExecHelper Handle information about hadoop job.
org.apache.hadoop.hive.ql.exec.mr.JobDebugger JobDebugger takes a RunningJob that has failed and grabs the top 4 failing tasks and outputs this information to the Hive CLI.
org.apache.hadoop.hive.ql.exec.mr.MapredLocalTask MapredLocalTask represents any local work (i.e.: client side work) that hive needs to execute.
org.apache.hadoop.hive.ql.exec.mr.Throttle Intelligence to make clients wait if the cluster is in a bad state.
org.apache.hadoop.hive.ql.exec.persistence.BytesBytesMultiHashMap HashMap that maps byte arrays to byte arrays with limited functionality necessary for MapJoin hash tables, with small memory overhead.
org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper Simple wrapper for persistent Hashmap implementing only the put/get/remove/clear interface.
org.apache.hadoop.hive.ql.exec.persistence.HybridHashTableContainer Hash table container that can have many partitions -- each partition has its own hashmap, as well as row container for small table and big table.
org.apache.hadoop.hive.ql.exec.persistence.KeyValueContainer An eager key/value container that puts every row directly to output stream.
org.apache.hadoop.hive.ql.exec.persistence.MapJoinBytesTableContainer Table container that serializes keys and values using LazyBinarySerDe into BytesBytesMultiHashMap, with very low memory overhead.
org.apache.hadoop.hive.ql.exec.persistence.MapJoinKey The base class for MapJoinKey.
org.apache.hadoop.hive.ql.exec.persistence.MapJoinTableContainerSerDe Serialization/deserialization of table container for join.
org.apache.hadoop.hive.ql.exec.persistence.ObjectContainer An eager object container that puts every row directly to output stream.
org.apache.hadoop.hive.ql.exec.persistence.RowContainer Simple persistent container for rows.
org.apache.hadoop.hive.ql.exec.persistence.UnwrapRowContainer Unwraps values from current key with valueIndex in mapjoin desc.
org.apache.hadoop.hive.ql.exec.spark.GroupByShuffler Shuffle group by operator.
org.apache.hadoop.hive.ql.exec.spark.HiveSparkClientFactory Factory class for spark client.
org.apache.hadoop.hive.ql.exec.spark.LocalHiveSparkClient LocalSparkClient submit Spark job in local driver, it's responsible for build spark client environment and execute spark work.
org.apache.hadoop.hive.ql.exec.spark.MapInput Input for mapper.
org.apache.hadoop.hive.ql.exec.spark.MapTran Mapper tran.
org.apache.hadoop.hive.ql.exec.spark.ReduceTran Reduce tran.
org.apache.hadoop.hive.ql.exec.spark.RemoteHiveSparkClient RemoteSparkClient is a wrapper of org.apache.hive.spark.client.SparkClient, which wrap a spark job request and send to an remote SparkContext.
org.apache.hadoop.hive.ql.exec.spark.ShuffleTran Shuffle tran.
org.apache.hadoop.hive.ql.exec.spark.SortByShuffler Sorting class for shuffler.
org.apache.hadoop.hive.ql.exec.spark.SparkTask Description of spark task.
org.apache.hadoop.hive.ql.exec.spark.SparkUtilities Contains utilities methods used as part of Spark tasks.
org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionImpl Implementation of spark session.
org.apache.hadoop.hive.ql.exec.spark.status.impl.JobMetricsListener Listener for job metrics.
org.apache.hadoop.hive.ql.exec.spark.status.impl.LocalSparkJobStatus Spark job local status.
org.apache.hadoop.hive.ql.exec.spark.status.impl.RemoteSparkJobStatus Used with remove spark client.
org.apache.hadoop.hive.ql.exec.tez.DagUtils DagUtils.
org.apache.hadoop.hive.ql.exec.tez.DynamicPartitionPruner DynamicPartitionPruner takes a list of assigned partitions at runtime (split generation) and prunes them using events generated during execution of the dag.
org.apache.hadoop.hive.ql.exec.tez.HiveSplitGenerator Generates splits inside the AM on the cluster.
org.apache.hadoop.hive.ql.exec.tez.MapRecordProcessor Process input from tez LogicalInput and write output - for a map plan Just pump the records through the query plan.
org.apache.hadoop.hive.ql.exec.tez.MapRecordSource Process input from tez LogicalInput and write output - for a map plan Just pump the records through the query plan.
org.apache.hadoop.hive.ql.exec.tez.MergeFileRecordProcessor Record processor for fast merging of files.
org.apache.hadoop.hive.ql.exec.tez.RecordProcessor Process input from tez LogicalInput and write output It has different subclasses for map and reduce processing
org.apache.hadoop.hive.ql.exec.tez.ReduceRecordProcessor Process input from tez LogicalInput and write output - for a map plan Just pump the records through the query plan.
org.apache.hadoop.hive.ql.exec.tez.ReduceRecordSource Process input from tez LogicalInput and write output - for a map plan Just pump the records through the query plan.
org.apache.hadoop.hive.ql.exec.tez.SplitGrouper SplitGrouper is used to combine splits based on head room and locality.
org.apache.hadoop.hive.ql.exec.tez.TezJobMonitor TezJobMonitor keeps track of a tez job while it's being executed.
org.apache.hadoop.hive.ql.exec.tez.TezProcessor Hive processor for Tez that forms the vertices in Tez and processes the data.
org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolManager This class is for managing multiple tez sessions particularly when HiveServer2 is being used to submit queries.
org.apache.hadoop.hive.ql.exec.tez.TezSessionState Holds session state related to Tez
org.apache.hadoop.hive.ql.exec.tez.TezTask TezTask handles the execution of TezWork.
org.apache.hadoop.hive.ql.exec.tez.tools.KeyValueInputMerger A KeyValuesReader implementation that returns a sorted stream of key-values by doing a sorted merge of the key-value in LogicalInputs.
org.apache.hadoop.hive.ql.exec.tez.tools.KeyValuesInputMerger A KeyValuesReader implementation that returns a sorted stream of key-values by doing a sorted merge of the key-value in LogicalInputs.
org.apache.hadoop.hive.ql.exec.vector.BytesColumnVector This class supports string and binary data by value reference.
org.apache.hadoop.hive.ql.exec.vecto.ColumnVector ColumnVector contains the shared structure for the sub-types, including NULL information, and whether this vector repeats, i.e.
org.apache.hadoop.hive.ql.exec.vector.DecimalColumnVector

A vector of HiveDecimalWritable objects.

org.apache.hadoop.hive.ql.exec.vector.DoubleColumnVector This class represents a nullable double precision floating point column vector.
org.apache.hadoop.hive.ql.exec.vector.LongColumnVector This class represents a nullable int column vector.
org.apache.hadoop.hive.ql.exec.vector.TimestampUtils

Utilities for Timestamps and the relevant conversions.

org.apache.hadoop.hive.ql.exec.vector.VectorAppMasterEventOperator App Master Event operator implementation.
org.apache.hadoop.hive.ql.exec.vector.VectorAssignRow This class assigns specified columns of a row from a Writable row objects.
org.apache.hadoop.hive.ql.exec.vector.VectorColumnOrderedMap This class collects column information for mapping vector columns, including the hive type name.
org.apache.hadoop.hive.ql.exec.vector.VectorColumnSetInfo Class to keep information on a set of typed vector columns.
org.apache.hadoop.hive.ql.exec.vector.VectorCopyRow This class copies specified columns of a row from one VectorizedRowBatch to another.
org.apache.hadoop.hive.ql.exec.vector.VectorDeserializeRow This class deserializes a serialization format into a row of a VectorizedRowBatch.
org.apache.hadoop.hive.ql.exec.vector.VectorExtractRow This class extracts specified VectorizedRowBatch row columns into writables.
org.apache.hadoop.hive.ql.exec.vector.VectorFileSinkOperator File Sink operator implementation.
org.apache.hadoop.hive.ql.exec.vector.VectorFilterOperator Filter operator implementation.
org.apache.hadoop.hive.ql.exec.vector.VectorGroupByOperator Vectorized GROUP BY operator implementation.
org.apache.hadoop.hive.ql.exec.vector.VectorHashKeyWrapper A hash map key wrapper for vectorized processing.
org.apache.hadoop.hive.ql.exec.vector.VectorLimitOperator Limit operator implementation Limits the number of rows to be passed on.
org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinBaseOperator The *NON-NATIVE* base vector map join operator class used by VectorMapJoinOperator and VectorMapJoinOuterFilteredOperator.
org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOperator The vectorized version of the MapJoinOperator.
org.apache.hadoop.hive.ql.exec.vector.VectorMapJoinOuterFilteredOperator This is the *NON-NATIVE* vector map join operator for just LEFT OUTER JOIN and filtered.
org.apache.hadoop.hive.ql.exec.vector.VectorMapOperator

The vectorized MapOperator.

org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator The vectorized reduce sink operator.
org.apache.hadoop.hive.ql.exec.vector.VectorSMBMapJoinOperator VectorSMBJoinOperator.
org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator Select operator implementation.
org.apache.hadoop.hive.ql.exec.vector.VectorSerializeRow This class serializes columns from a row in a VectorizedRowBatch into a serialization format.
org.apache.hadoop.hive.ql.exec.vector.VectorizationContext Context class for vectorization execution.
org.apache.hadoop.hive.ql.exec.vector.VectorizedBatchUtil The vectorized MapOperator.
org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch A VectorizedRowBatch is a set of rows, organized with each column as a vector.
org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatchCtx Context for Vectorized row batch.
org.apache.hadoop.hive.ql.exec.vector.expressions.CastDecimalToTimestamp Type cast decimal to timestamp.
org.apache.hadoop.hive.ql.exec.vector.expressions.CastTimestampToDecimal To be used to cast timestamp to decimal.
org.apache.hadoop.hive.ql.exec.vector.expressions.ColAndCol Evaluate AND of 2 or more boolean columns and store the boolean result in the output boolean column.
org.apache.hadoop.hive.ql.exec.vector.expressions.ColOrCol Evaluate OR of 2 or more boolean columns and store the boolean result in the output boolean column.
org.apache.hadoop.hive.ql.exec.vector.expressions.ConstantVectorExpression Constant is represented as a vector with repeating values.
org.apache.hadoop.hive.ql.exec.vector.expressions.DecimalUtil Utility functions for vector operations on decimal values.
org.apache.hadoop.hive.ql.exec.vector.expressions.FilterExprOrExpr Represents an Or expression.
org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStringColumnInList Evaluate an IN filter on a batch for a vector of strings.
org.apache.hadoop.hive.ql.exec.vector.expressions.FuncRoundWithNumDigitsDecimalToDecimal Function for rounding decimals.
org.apache.hadoop.hive.ql.exec.vector.expressions.MathExpr Math expression evaluation helper functions.
org.apache.hadoop.hive.ql.exec.vector.expressions.NullUtil Utility functions to handle null propagation.
org.apache.hadoop.hive.ql.exec.vector.expressions.StringColumnInList Evaluate an IN boolean expression (not a filter) on a batch for a vector of strings.
org.apache.hadoop.hive.ql.exec.vector.expressions.StringExpr String expression evaluation helper functions.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColCol Vectorized user defined function for adding columns.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateAddColScalar Vectorized user defined function for adding column and scalar.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateDiffColCol Vectorized user defined function forfinding difference between two columns.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateLong Vectorized version of TO_DATE(TIMESTAMP)/TO_DATE(DATE).
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateString Vectorized version of TO_DATE(STRING) As TO_DATE() now returns DATE type, this should be the same behavior as the DATE cast operator.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinCommonOperator Common operator class for native vectorized map join.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinGenerateResultOperator Contains methods for generating vectorized join results and forwarding batchs.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyGenerateResultOperator This class has methods for generating vectorized join results for the big table only variation of inner joins.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyLongOperator

Specialized class for doing a vectorized map join that is an inner join on a Single-Column Long and only big table columns appear in the join result so a hash multi-set is used.

org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyMultiKeyOperator

Specialized class for doing a vectorized map join that is an inner join on Multi-Key and only big table columns appear in the join result so a hash multi-set is used.

org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerBigOnlyStringOperator Specialized class for doing a vectorized map join that is an inner join on a Single-Column String and only big table columns appear in the join result so a hash multi-set is used.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerGenerateResultOperator Contains methods for generating vectorized join results for inner joins.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerLongOperator Specialized class for doing a vectorized map join that is an inner join on a Single-Column Long and only big table columns appear in the join result so a hash multi-set is used.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerMultiKeyOperator Specialized class for doing a vectorized map join that is an inner join on a Multi-Key using a hash map.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinInnerStringOperator

Specialized class for doing a vectorized map join that is an inner join on a Single-Column String using a hash map.

org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiGenerateResultOperator Contains methods for generating vectorized join results for left semi joins.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiLongOperator Specialized class for doing a vectorized map join that is an left semi join on a Single-Column Long using a hash set.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiMultiKeyOperator

Specialized class for doing a vectorized map join that is an left semi join on Multi-Key using hash set.

org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinLeftSemiStringOperator Specialized class for doing a vectorized map join that is an left semi join on a Single-Column String using a hash set.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterGenerateResultOperator Contains methods for generating vectorized join results for outer joins.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterLongOperator Specialized class for doing a vectorized map join that is an outer join on a Single-Column Long using a hash map.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterMultiKeyOperator Specialized class for doing a vectorized map join that is an outer join on Multi-Key using a hash map.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinOuterStringOperator Specialized class for doing a vectorized map join that is an outer join on a Single-Column String using a hash map.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.VectorMapJoinRowBytesContainer An eager bytes container that puts row bytes to an output stream.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashMap

Bytes key hash map optimized for vector map join. This is the abstract base for the multi-key and string bytes key hash map implementations.

org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashMultiSet Bytes key hash multi-set optimized for vector map join. This is the abstract base for the multi-key and string bytes key hash multi-set implementations.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastBytesHashUtil Utilities for bytes key hash multi-set optimized for vector map join.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastHashTable Vector map join fast hash table.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastKeyStore Vector map join fast key store.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashMap Vector map join fact long hash map.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashMultiSet Vector mapr join fast long hash multi set.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashSet

A single LONG key hash set optimized for vector map join.

org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashTable

A single long value map optimized for vector map join.

org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastLongHashUtil Utilities for vector map join of single long value.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastMultiKeyHashMap A multi-key value hash map optimized for vector map join. The key is stored as the provided bytes (uninterpreted).
org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastMultiKeyHashMultiSet A multi-key hash multi-set optimized for vector map join. The key is stored as the provided bytes (uninterpreted).
org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastMultiKeyHashSet A multi-key hash set optimized for vector map join. The key is stored as the provided bytes (uninterpreted).
org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastStringCommon A single byte array value hash map optimized for vector map join.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.fast.VectorMapJoinFastTableContainer HashTableLoader for Tez constructs the hashtable from records read from a broadcast edge.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashMapResult Abstract class for a hash map result. For reading the values, one-by-one.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.hashtable.VectorMapJoinHashTableResult Root abstract class for a hash table result.
org.apache.hadoop.hive.ql.exec.vector.mapjoin.optimized.VectorMapJoinOptimizedCreateHashTable Create hash table for vector map join.
org.apache.hadoop.hive.ql.hooks.HookContext Hook Context keeps all the necessary information for all the hooks.
org.apache.hadoop.hive.ql.hooks.PostExecutePrinter Implementation of a post execute hook that simply prints out its parameters to standard output.
org.apache.hadoop.hive.ql.hooks.PreExecutePrinter Implementation of a pre execute hook that simply prints out its parameters to standard output.
org.apache.hadoop.hive.ql.index.HiveIndex Holds index related constants.
org.apache.hadoop.hive.ql.index.HiveIndexQueryContext Used to pass information between the IndexProcessor and the plugin IndexHandler during query processing
org.apache.hadoop.hive.ql.index.HiveIndexResult HiveIndexResult parses the input stream from an index query to generate a list of file splits to query.
org.apache.hadoop.hive.ql.index.HiveIndexedInputFormat Input format for doing queries that use indexes.
org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer IndexPredicateAnalyzer decomposes predicates, separating the parts which can be satisfied by an index from the parts which cannot.
org.apache.hadoop.hive.ql.index.IndexSearchCondition IndexSearchCondition represents an individual search condition found by IndexPredicateAnalyzer.
org.apache.hadoop.hive.ql.index.TableBasedIndexHandler Index handler for indexes that use tables to store indexes.
org.apache.hadoop.hive.ql.index.compact.HiveCompactIndexInputFormat Hive compact index input format.
org.apache.hadoop.hive.ql.io.AcidUtils Utilities that are shared by all of the ACID input and output formats.
org.apache.hadoop.hive.ql.io.BucketizedHiveInputFormat BucketizedHiveInputFormat serves the similar function as hiveInputFormat but its getSplits() always group splits from one input file into one wrapper split.
org.apache.hadoop.hive.ql.io.CombineHiveInputFormat CombineHiveInputFormat is a parameterized InputFormat which looks at the path name and determine the correct InputFormat for that path name from mapredPlan.pathToPartitionInfo().
org.apache.hadoop.hive.ql.io.HiveFileFormatUtils An util class for various Hive file format tasks.
org.apache.hadoop.hive.ql.io.HiveInputFormat HiveInputFormat is a parameterized InputFormat which looks at the path name and determine the correct InputFormat for that path name from mapredPlan.pathToPartitionInfo().
org.apache.hadoop.hive.ql.io.IOConstants Input output constants.
org.apache.hadoop.hive.ql.io.IOContext IOContext basically contains the position information of the current key/value.
org.apache.hadoop.hive.ql.io.NullRowsInputFormat NullRowsInputFormat outputs null rows, maximum 100.
org.apache.hadoop.hive.ql.io.OneNullRowInputFormat OneNullRowInputFormat outputs one null row.
org.apache.hadoop.hive.ql.io.RCFileInputFormat RCFileInputFormat.
org.apache.hadoop.hive.ql.io.SequenceFileInputFormatChecker SequenceFileInputFormatChecker.
org.apache.hadoop.hive.ql.io.avro.AvroContainerOutputFormat Write to an Avro file from a Hive process.
org.apache.hadoop.hive.ql.io.merge.MergeFileMapper Mapper for fast file merging of ORC and RC files.
org.apache.hadoop.hive.ql.io.merge.MergeFileTask Task for fast merging of ORC and RC files.
org.apache.hadoop.hive.ql.io.orc.CompressionKind An enumeration that lists the generic compression algorithms that can be applied to ORC files.
org.apache.hadoop.hive.ql.io.orc.OrcFile Contains factory methods to read or write ORC files.
org.apache.hadoop.hive.ql.io.orc.OrcFileKeyWrapper Key for OrcFileMergeMapper task.
org.apache.hadoop.hive.ql.io.orc.OrcFileStripeMergeRecordReader Record reader for orc file stripe merge.
org.apache.hadoop.hive.ql.io.orc.OrcFileValueWrapper Value for OrcFileMergeMapper.
org.apache.hadoop.hive.ql.io.orc.OrcInputFormat A MapReduce/Hive input format for ORC files.
org.apache.hadoop.hive.ql.io.orc.OrcNewSplit OrcFileSplit.
org.apache.hadoop.hive.ql.io.orc.OrcRecordUpdater A RecordUpdater where the files are stored as ORC.
org.apache.hadoop.hive.ql.io.orc.OrcSerde A serde class for ORC.
org.apache.hadoop.hive.ql.io.orc.OrcSplit OrcFileSplit.
org.apache.hadoop.hive.ql.io.orc.ReaderImpl Implementation of record reader.
org.apache.hadoop.hive.ql.io.orc.VectorizedOrcInputFormat A MapReduce/Hive input format for ORC files.
org.apache.hadoop.hive.ql.io.orc.WriterImpl An ORC file writer.
org.apache.hadoop.hive.ql.io.parquet.LeafFilterFactory Factory class for leaf filter.
org.apache.hadoop.hive.ql.io.parquet.MapredParquetOutputFormat A Parquet OutputFormat for Hive (with the deprecated package mapred)
org.apache.hadoop.hive.ql.io.parquet.convert.DataWritableRecordConverter A MapWritableReadSupport, encapsulates the tuples
org.apache.hadoop.hive.ql.io.parquet.convert.ETypeConverter.BinaryConverter ETypeConverter is an easy way to set the converter for the right type.
org.apache.hadoop.hive.ql.io.parquet.convert.HiveCollectionConverter Converter for collections.
org.apache.hadoop.hive.ql.io.parquet.convert.HiveGroupConverter Converter for groups.
org.apache.hadoop.hive.ql.io.parquet.convert.HiveStructConverter A MapWritableGroupConverter, real converter between hive and parquet types recursively for complex types.
org.apache.hadoop.hive.ql.io.parquet.read.DataWritableReadSupport A MapWritableReadSupport Manages the translation between Hive and Parquet
org.apache.hadoop.hive.ql.io.parquet.read.ParquetRecordReaderWrapper Wrapper for parquet record reader.
org.apache.hadoop.hive.ql.io.parquet.serde.ParquetHiveSerDe A ParquetHiveSerDe for Hive (with the deprecated package mapred)
org.apache.hadoop.hive.ql.io.parquet.write.DataWritableWriter DataWritableWriter sends a record to the Parquet API with the expected schema in order to be written to a file.
org.apache.hadoop.hive.ql.io.parquet.write.ParquetRecordWriterWrapper Wrapper for parquet record writer.
org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanMapper PartialScanMapper.
org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanTask PartialScanTask.
org.apache.hadoop.hive.ql.io.rcfile.stats.PartialScanWork Partial Scan Work.
org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateMapper A factory for creating SearchArguments, as well as modifying those created by this factory.
org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateTask Base class for operator graph walker this class takes list of starting ops and walks them one by one.
org.apache.hadoop.hive.ql.io.sarg.SearchArgumentFactory A factory for creating SearchArguments, as well as modifying those created by this factory.
org.apache.hadoop.hive.ql.lib.DefaultGraphWalker Base class for operator graph walker this class takes list of starting ops and walks them one by one.
org.apache.hadoop.hive.ql.lib.RuleExactMatch Implentation of the Rule interface for Nodes Used in Node dispatching to dispatch process/visitor functions for Nodes.
org.apache.hadoop.hive.ql.lockmgr.DbLockManager An implementation of HiveLockManager for use with org.apache.hadoop.hive.ql.lockmgr.DbTxnManager.
org.apache.hadoop.hive.ql.lockmgr.DbTxnManager An implementation of HiveTxnManager that stores the transactions in the metastore database.
org.apache.hadoop.hive.ql.lockmgr.HiveLockObject The class is used to uniquely identify a HiveLockObject.
org.apache.hadoop.hive.ql.lockmgr.LockException Exception from lock manager.
org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock The class is used to uniquely identify ZookeeperHiveLock.
org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager Zookeeper lock manager.
org.apache.hadoop.hive.ql.log.PerfLogger PerfLogger.
org.apache.hadoop.hive.ql.metadata.Hive

Contains functions that implement meta data/DDL operations using calls to the metastore.
org.apache.hadoop.hive.ql.metadata.HiveException Generic exception class for Hive.
org.apache.hadoop.hive.ql.metadata.HiveMetaStoreChecker Verify that the information in the metastore matches what is on the filesystem.
org.apache.hadoop.hive.ql.metadata.HiveUtils General collection of helper functions.
org.apache.hadoop.hive.ql.metadata.Partition A Hive Table Partition: is a fundamental storage unit within a Table.
org.apache.hadoop.hive.ql.metadata.SessionHiveMetaStoreClient Client for hivemetastore during session.
org.apache.hadoop.hive.ql.metadata.Table A Hive Table: is a fundamental unit of data in Hive that shares a common schema/DDL.
org.apache.hadoop.hive.ql.metadata.VirtualColumn Provides metadata that is not stored in table itself.
org.apache.hadoop.hive.ql.metadata.formatting.JsonMetaDataFormatter Format table and index information for machine readability using json.
org.apache.hadoop.hive.ql.metadata.formatting.MetaDataFormatUtils This class provides methods to format table and index information.
org.apache.hadoop.hive.ql.optimizer.BucketMapJoinOptimizer this transformation does bucket map join optimization.
org.apache.hadoop.hive.ql.optimizer.BucketingSortingReduceSinkOptimizer This transformation does optimization for enforcing bucketing and sorting.
org.apache.hadoop.hive.ql.optimizer.ColumnPruner Implementation of one of the rule-based optimization steps.
org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx This class implements the processor context for Column Pruner.
org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory Factory for generating the different node processors used by ColumnPruner.
org.apache.hadoop.hive.ql.optimizer.ConstantPropagate Implementation of one of the rule-based optimization steps.
org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcCtx Implements the processor context for Constant Propagate.
org.apache.hadoop.hive.ql.optimizer.ConstantPropagateProcFactory Factory for generating the different node processors used by ConstantPropagate.
org.apache.hadoop.hive.ql.optimizer.ConvertJoinMapJoin ConvertJoinMapJoin is an optimization that replaces a common join (aka shuffle join) with a map join (aka broadcast or fragment replicate join when possible.
org.apache.hadoop.hive.ql.optimizer.GenMRProcContext Processor Context for creating map reduce task.
org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils General utility common functions for the Processor to convert operator into map-reduce tasks.
org.apache.hadoop.hive.ql.optimizer.GlobalLimitOptimizer This optimizer is used to reduce the input size for the query for queries which are specifying a limit.
org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer This transformation does group by optimization.
org.apache.hadoop.hive.ql.optimizer.IdentityProjectRemover This optimization tries to remove SelectOperator from tree which don't do any processing except forwarding columns from its parent to its children.
org.apache.hadoop.hive.ql.optimizer.JoinReorder Implementation of rule-based join table reordering optimization.
org.apache.hadoop.hive.ql.optimizer.LimitPushdownOptimizer Make RS calculate top-K selection for limit clause.
org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor Implementation of one of the rule-based map join optimization.
org.apache.hadoop.hive.ql.optimizer.NonBlockingOpDeDupProc Merges SEL-SEL or FIL-FIL into single operator
org.apache.hadoop.hive.ql.optimizer.ReduceSinkMapJoinProc This processor addresses the RS-MJ case that occurs in Tez on the small/hash table. The work that RS will be a part of must be connected to the MJ work via a broadcast edge.
org.apache.hadoop.hive.ql.optimizer.SamplePruner The transformation step that does sample pruning.
org.apache.hadoop.hive.ql.optimizer.SimpleFetchAggregation Execute final aggregation stage for simple fetch query on fetch task.
org.apache.hadoop.hive.ql.optimizer.SimpleFetchOptimizer Tries to convert simple fetch query to single fetch task, which fetches rows directly from location of table/partition.
org.apache.hadoop.hive.ql.optimizer.SkewJoinOptimizer SkewJoinOptimizer.
org.apache.hadoop.hive.ql.optimizer.SortedDynPartitionOptimizer When dynamic partitioning (with or without bucketing and sorting) is enabled, this optimization sorts the records on partition, bucket and sort columns respectively before inserting records into the destination table.
org.apache.hadoop.hive.ql.optimizer.SortedMergeBucketMapJoinOptimizer Replace a bucket map join with a sorted merge map join.
org.apache.hadoop.hive.ql.optimizer.StatsOptimizer There is a set of queries which can be answered entirely from statistics stored in metastore.
org.apache.hadoop.hive.ql.optimizer.Transform Optimizer interface.
org.apache.hadoop.hive.ql.optimizer.calcite.HiveCalciteUtil Generic utility functions needed for Calcite based Hive CBO.
org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelOptUtil Splits different join conditions.
org.apache.hadoop.hive.ql.optimizer.calcite.RelOptHiveTable Class for handling all table metadata.
org.apache.hadoop.hive.ql.optimizer.calcite.TraitsUtil Traits utilities.
org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveRelMdCost HiveRelMdCost supplies the implementation of cost model.
org.apache.hadoop.hive.ql.optimizer.calcite.cost.HiveVolcanoPlanner Refinement of org.apache.calcite.plan.volcano.VolcanoPlanner for Hive.
org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveAggregate Describing aggregate function as relational operator.
org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveFilter Describing filter function as relational operator.
org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin Describing join function as relational operator.
org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveProject Creates a HiveProject.
org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSemiJoin Describing semi join operator as relational operator.
org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveTableScan Relational expression representing a scan of a HiveDB collection.
org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveUnion Describing union operator as relational operator.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterJoinRule Creates a PushFilterPastJoinRule with an explicit root operand.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinProjectTransposeRule Transpose rule for hive join project.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterSetOpTransposeRule Creates a HiveFilterSetOpTransposeRule.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveInsertExchange4JoinRule Not an optimization rule.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinAddNotNullRule Creates an HiveJoinAddNotNullRule.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinPushTransitivePredicatesRule Planner rule that infers predicates from on a org.apache.calcite.rel.core.Join and creates org.apache.calcite.rel.core.Filters if those predicates can be pushed to its inputs.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinToMultiJoinRule Rule that merges a join with multijoin/join children if the equi compared the same set of input columns.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HivePreFilteringRule Pull out deterministic expressions from non-deterministic and push down deterministic expressions as a separate filter.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveProjectMergeRule ProjectMergeRule merges a org.apache.calcite.rel.core.Project into another org.apache.calcite.rel.core.Project, provided the projects aren't projecting identical sets of input references.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveRelFieldTrimmer Hive relational expression field trimmer.
org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdCollation Hive relational expression metadata collation.
org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdDistinctRowCount Hive relational expression metadata.
org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdDistribution Hive relational expression metadata distribuiton.
org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdMemory Hive relational expression metadata memory
org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdParallelism Hive relational expression metadata parallelism.
org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdRowCount Hive relational expression metadata row count.
org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdSelectivity Hive relational expression metadata selectivity.
org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdSize Hive relational expression metadata size.
org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdUniqueKeys Hive relational expression metadata unique keys.
org.apache.hadoop.hive.ql.optimizer.calcite.translator.ASTConverter Abstract syntax tree converter.
org.apache.hadoop.hive.ql.optimizer.calcite.translator.ExprNodeConverter Expression node converter.
org.apache.hadoop.hive.ql.optimizer.calcite.translator.HiveOpConverter Hive operation converter.
org.apache.hadoop.hive.ql.optimizer.calcite.translator.HiveOpConverterPostProc Post processing hive operation converter.
org.apache.hadoop.hive.ql.optimizer.calcite.translator.PlanModifierForASTConv Modifying plan for converting abstract syntax tree.
org.apache.hadoop.hive.ql.optimizer.calcite.translator.PlanModifierForReturnPath Modifying plan for operation tree.
org.apache.hadoop.hive.ql.optimizer.calcite.translator.RexNodeConverter Row expression node converter.
org.apache.hadoop.hive.ql.optimizer.calcite.translator.SqlFunctionConverter Converting SQL function.
org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationOptimizer Implementation of Correlation Optimizer.
org.apache.hadoop.hive.ql.optimizer.correlation.CorrelationUtilities Utilities for both CorrelationOptimizer and ReduceSinkDeDuplication.
org.apache.hadoop.hive.ql.optimizer.correlation.ReduceSinkDeDuplication If two reducer sink operators share the same partition/sort columns and order, they can be merged.
org.apache.hadoop.hive.ql.optimizer.index.RewriteGBUsingIndex RewriteGBUsingIndex is implemented as one of the Rule-based Optimizations.
org.apache.hadoop.hive.ql.optimizer.index.RewriteParseContextGenerator RewriteParseContextGenerator is a class that offers methods to generate operator tree for input queries.
org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory Expression processor factory for lineage.
org.apache.hadoop.hive.ql.optimizer.lineage.Generator Generates the lineage information for the columns and tables from the plan before it goes through other optimization phases.
org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx Contains the lineage context that is passed while walking the operator tree in Lineage.
org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory Operator factory for the rule processors for lineage.
org.apache.hadoop.hive.ql.optimizer.listbucketingpruner.ListBucketingPruner The transformation step that does list bucketing pruning.
org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.AnnotateWithOpTraits This class annotates each operator with its traits. The OpTraits class specifies the traits that are populated for each operator.
org.apache.hadoop.hive.ql.optimizer.pcr.PartitionConditionRemover The transformation step that does partition condition remover.
org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory Expression processor factory for partition condition removing.
org.apache.hadoop.hive.ql.optimizer.physical.CrossProductCheck Check each MapJoin and ShuffleJoin Operator to see they are performing a cross product.
org.apache.hadoop.hive.ql.optimizer.physical.Vectorizer Class to define vectorization.
org.apache.hadoop.hive.ql.optimizer.ppr.PartitionExpressionForMetastore The basic implementation of PartitionExpressionProxy that uses ql package classes.
org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner The transformation step that does partition pruning.
org.apache.hadoop.hive.ql.optimizer.spark.SparkReduceSinkMapJoinProc This processor addresses the RS-MJ case that occurs in spark on the small/hash table side of things. The work that RS will be a part of must be connectedto the MJ work via be a broadcast edge.
org.apache.hadoop.hive.ql.optimizer.stats.annotation.AnnotateWithStatistics Create a list of top op nodes
org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcessor FileSinkProcessor is a simple rule to remember seen unions for later processing.
org.apache.hadoop.hive.ql.parse.ASTNode Definition of abstract syntax tree node.
org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer BaseSemanticAnalyzer.
org.apache.hadoop.hive.ql.parse.CalcitePlanner Cost based optimizer planner.
org.apache.hadoop.hive.ql.parse.ColumnAccessAnalyzer Analysis of column access.
org.apache.hadoop.hive.ql.parse.ColumnStatsSemanticAnalyzer ColumnStatsSemanticAnalyzer.
org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer DDLSemanticAnalyzer.
org.apache.hadoop.hive.ql.parse.ExplainSQRewriteSemanticAnalyzer ExplainSQRewriteSemanticAnalyzer.
org.apache.hadoop.hive.ql.parse.ExplainSemanticAnalyzer ExplainSemanticAnalyzer.
org.apache.hadoop.hive.ql.parse.ExportSemanticAnalyzer ExportSemanticAnalyzer.
org.apache.hadoop.hive.ql.parse.FunctionSemanticAnalyzer FunctionSemanticAnalyzer.
org.apache.hadoop.hive.ql.parse.GenTezProcContext GenTezProcContext.
org.apache.hadoop.hive.ql.parse.GenTezUtils GenTezUtils is a collection of shared helper methods to produce TezWork.
org.apache.hadoop.hive.ql.parse.GlobalLimitCtx context for pruning inputs.
org.apache.hadoop.hive.ql.parse.ImportSemanticAnalyzer ImportSemanticAnalyzer.
org.apache.hadoop.hive.ql.parse.LoadSemanticAnalyzer LoadSemanticAnalyzer.
org.apache.hadoop.hive.ql.parse.MacroSemanticAnalyzer MacroSemanticAnalyzer.
org.apache.hadoop.hive.ql.parse.MapReduceCompiler Compiling list of tasks.
org.apache.hadoop.hive.ql.parse.MetaDataExportListener Listens for drop events and, if set, exports the table's metadata as JSON to the trash of the user performing the drop
org.apache.hadoop.hive.ql.parse.ParseContext Parse Context: The current parse context.
org.apache.hadoop.hive.ql.parse.ParseDriver ParseDriver.
org.apache.hadoop.hive.ql.parse.ParseUtils Library of utility functions used in the parse code.
org.apache.hadoop.hive.ql.parse.QB Implementation of the query block.
org.apache.hadoop.hive.ql.parse.QBParseInfo Implementation of the parse information related to a query block.
org.apache.hadoop.hive.ql.parse.RowResolver Implementation of the Row Resolver.
org.apache.hadoop.hive.ql.parse.SemanticAnalyzer Implementation of the semantic analyzer.
org.apache.hadoop.hive.ql.parse.SemanticAnalyzerFactory SemanticAnalyzerFactory.
org.apache.hadoop.hive.ql.parse.SplitSample Stores all the information specified in the TABLESAMPLE(...) clause.
org.apache.hadoop.hive.ql.parse.TaskCompiler TaskCompiler is a the base class for classes that compile operator pipelines into tasks.
org.apache.hadoop.hive.ql.parse.TezCompiler TezCompiler translates the operator plan into TezTasks.
org.apache.hadoop.hive.ql.parse.TypeCheckCtx This class implements the context information that is used for typechecking phase in query compilation.
org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory The Factory for creating typecheck processors.
org.apache.hadoop.hive.ql.parse.UpdateDeleteSemanticAnalyzer A subclass of the org.apache.hadoop.hive.ql.parse.SemanticAnalyzer that just handles update and delete statements.
org.apache.hadoop.hive.ql.parse.WindowingSpec Windowing Specification.
org.apache.hadoop.hive.ql.parse.spark.GenSparkProcContext GenSparkProcContext maintains information about the tasks and operators as we walk the operator tree to break them into SparkTasks.
org.apache.hadoop.hive.ql.parse.spark.GenSparkUtils GenSparkUtils is a collection of shared helper methods to produce SparkWork Cloned from GenTezUtils.
org.apache.hadoop.hive.ql.parse.spark.GenSparkWorkWalker Walks the operator tree in DFS fashion.
org.apache.hadoop.hive.ql.parse.spark.OptimizeSparkProcContext OptimizeSparkProcContext.
org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc Operator description.
org.apache.hadoop.hive.ql.plan.AlterTableDesc AlterTableDesc.
org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc Contains information needed to modify a partition or a table
org.apache.hadoop.hive.ql.plan.BaseWork BaseWork.
org.apache.hadoop.hive.ql.plan.ColumnStatsDesc Contains the information needed to persist column level statistics
org.apache.hadoop.hive.ql.plan.ColumnStatsWork ColumnStats Work.
org.apache.hadoop.hive.ql.plan.CommonMergeJoinDesc Description of merge join operator.
org.apache.hadoop.hive.ql.plan.CreateTableDesc CreateTableDesc.
org.apache.hadoop.hive.ql.plan.CreateViewDesc CreateViewDesc.
org.apache.hadoop.hive.ql.plan.DDLWork DDLWork.
org.apache.hadoop.hive.ql.plan.DropTableDesc DropTableDesc.
org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx Dynamic partition context.
org.apache.hadoop.hive.ql.plan.DynamicPruningEventDesc Dynamic pruning event description.
org.apache.hadoop.hive.ql.plan.ExplainWork ExplainWork.
org.apache.hadoop.hive.ql.plan.ExprNodeDesc ExprNodeDesc.
org.apache.hadoop.hive.ql.plan.ExprNodeDescUtils Utilities for expression node description.
org.apache.hadoop.hive.ql.plan.FetchWork FetchWork.
org.apache.hadoop.hive.ql.plan.FileSinkDesc FileSinkDesc.
org.apache.hadoop.hive.ql.plan.FilterDesc FilterDesc.
org.apache.hadoop.hive.ql.plan.GroupByDesc GroupByDesc.
org.apache.hadoop.hive.ql.plan.HashTableSinkDesc Map Join operator Descriptor implementation.
org.apache.hadoop.hive.ql.plan.JoinCondDesc Join conditions Descriptor implementation.
org.apache.hadoop.hive.ql.plan.JoinDesc Join operator Descriptor implementation.
org.apache.hadoop.hive.ql.plan.LateralViewJoinDesc LateralViewJoinDesc.
org.apache.hadoop.hive.ql.plan.LimitDesc LimitDesc.
org.apache.hadoop.hive.ql.plan.LoadTableDesc LoadTableDesc.
org.apache.hadoop.hive.ql.plan.MapJoinDesc Map Join operator Descriptor implementation.
org.apache.hadoop.hive.ql.plan.MapWork MapWork represents all the information used to run a map task on the cluster.
org.apache.hadoop.hive.ql.plan.MapredWork MapredWork.
org.apache.hadoop.hive.ql.plan.MergeJoinWork Creating merge join work.
org.apache.hadoop.hive.ql.plan.PartitionDesc PartitionDesc.
org.apache.hadoop.hive.ql.plan.PlanUtils PlanUtils.
org.apache.hadoop.hive.ql.plan.ReduceSinkDesc ReduceSinkDesc.
org.apache.hadoop.hive.ql.plan.ReduceWork ReduceWork represents all the information used to run a reduce task on the cluster.
org.apache.hadoop.hive.ql.plan.SelectDesc SelectDesc.
org.apache.hadoop.hive.ql.plan.SparkHashTableSinkDesc Map Join operator Descriptor implementation.
org.apache.hadoop.hive.ql.plan.Statistics Statistics.
org.apache.hadoop.hive.ql.plan.StatsWork ConditionalStats.
org.apache.hadoop.hive.ql.plan.TableScanDesc Table Scan Descriptor Currently, data is only read from a base source as part of map-reduce framework.
org.apache.hadoop.hive.ql.plan.TezWork TezWork.
org.apache.hadoop.hive.ql.plan.UnionWork Simple wrapper for union all cases.
org.apache.hadoop.hive.ql.plan.VectorGroupByDesc VectorGroupByDesc.
org.apache.hadoop.hive.ql.plan.ptf.BoundaryDef Map-reduce boundaries definition.
org.apache.hadoop.hive.ql.plan.ptf.CurrentRowDef Current row definition.
org.apache.hadoop.hive.ql.plan.ptf.OrderExpressionDef Order expression definition.
org.apache.hadoop.hive.ql.plan.ptf.RangeBoundaryDef Range boundary definition.
org.apache.hadoop.hive.ql.plan.ptf.ValueBoundaryDef Value boundary definition.
org.apache.hadoop.hive.ql.plan.ptf.WindowFrameDef Window frame definition.
org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo Context for Expression Walker for determining predicate pushdown candidates It contains a ExprInfo object for each expression that is processed.
org.apache.hadoop.hive.ql.ppd.OpProcFactory Operator factory for predicate pushdown processing of operator graph Each operator determines the pushdown predicates by walking the expression tree.
org.apache.hadoop.hive.ql.ppd.PredicatePushDown Implements predicate pushdown.
org.apache.hadoop.hive.ql.ppd.PredicateTransitivePropagate Propagates filters to other aliases based on join condition
org.apache.hadoop.hive.ql.ppd.SyntheticJoinPredicate Creates synthetic predicates that represent "IN (keylist other table)"
org.apache.hadoop.hive.ql.processors.AddResourceProcessor AddResourceProcessor.
org.apache.hadoop.hive.ql.processors.CommandProcessorResponse Encapsulates the basic response info returned by classes the implement the CommandProcessor interface.
org.apache.hadoop.hive.ql.processors.CompileProcessor Processor allows users to build code inside a hive session, then use this code as a UDF, Serde, or even a more complex entity like an input format or hook.
org.apache.hadoop.hive.ql.processors.CryptoProcessor Processes HADOOP commands used for HDFS encryption.
org.apache.hadoop.hive.ql.processors.DeleteResourceProcessor DeleteResourceProcessor.
org.apache.hadoop.hive.ql.processors.DfsProcessor DfsProcessor.
org.apache.hadoop.hive.ql.processors.SetProcessor SetProcessor.
org.apache.hadoop.hive.ql.security.authorization.AuthorizationPreEventListener AuthorizationPreEventListener : A MetaStorePreEventListener that performs authorization/authentication checks on the metastore-side.
org.apache.hadoop.hive.ql.security.authorization.AuthorizationUtils Utility code shared by hive internal code and sql standard authorization plugin implementation
org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase Class for authorization that returns userNames and groupNames.
org.apache.hadoop.hive.ql.security.authorization.plugin.AuthorizationMetaStoreFilterHook Metastore filter hook for filtering out the list of objects that the current authorization implementation does not allow user to see
org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthorizerImpl Convenience implementation of HiveAuthorizer.
org.apache.hadoop.hive.ql.security.authorization.plugin.HiveAuthzContext Provides context information in authorization check call that can be used for auditing and/or authorization.
org.apache.hadoop.hive.ql.security.authorization.plugin.HivePrivilegeObject Represents the object on which privilege is being granted/revoked, and objects being used in queries.
org.apache.hadoop.hive.ql.security.authorization.plugin.HiveV1Authorizer Hive v1 authorization class.
org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.DummyHiveAuthorizationValidator A no-op HiveAuthorizationValidator for use from hive cli.
org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLAuthorizationUtils Utilities for SQL based authorization.
org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAccessController Implements functionality of access control statements for sql standard based authorization
org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdHiveAuthorizationValidator Class to check if user has privileges to perform certain action according to SQL standart hive authorization.
org.apache.hadoop.hive.ql.session.LineageState LineageState.
org.apache.hadoop.hive.ql.session.OperationLog OperationLog wraps the actual operation log file, and provides interface for accessing, reading, writing, and removing the file.
org.apache.hadoop.hive.ql.session.SessionState SessionState encapsulates common data associated with a session.
org.apache.hadoop.hive.ql.stats.StatsFactory A factory of stats publisher and aggregator implementations of the StatsPublisher and StatsAggregator interfaces.
org.apache.hadoop.hive.ql.stats.StatsUtils Utilities of stats publisher and aggregator.
org.apache.hadoop.hive.ql.stats.fs.FSStatsAggregator File system stats aggregator.
org.apache.hadoop.hive.ql.stats.fs.FSStatsPublisher File system stats publisher.
org.apache.hadoop.hive.ql.txn.compactor.CompactorMR Performs compactions via an MR job.
org.apache.hadoop.hive.ql.txn.compactor.Worker Performs compactions.
org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage GenericUDAFAverage.
org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStreamingEvaluator User defined aggregate function streaming evaluator.
org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum GenericUDAFSum.
org.apache.hadoop.hive.ql.udf.generic.GenericUDF A Generic User-defined function (GenericUDF) for the use with Hive.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFBasePad A Generic User-defined function (GenericUDF) for the use with Hive.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge GenericUDFBridge encapsulates UDF to provide the same interface as GenericUDF.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateAdd UDFDateAdd.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFDateSub UDFDateSub.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFFromUtcTimestamp Generic user defined fuction to compute UTC timestamp.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFGreatest GenericUDF Class for SQL construct "greatest(v1, v2, ..
org.apache.hadoop.hive.ql.udf.generic.GenericUDFLeast GenericUDF Class for SQL construct "least(v1, v2, ..
org.apache.hadoop.hive.ql.udf.generic.GenericUDFLpad UDFLpad.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPAnd GenericUDF Class for computing and.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqual GenericUDF Class for operation EQUAL.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrGreaterThan GenericUDF Class for operation EqualOrGreaterThan.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrLessThan GenericUDF Class for operation EqualOrLessThan.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPGreaterThan GenericUDF Class for operation GreaterThan.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPLessThan GenericUDF Class for operation LessThan.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotEqual GenericUDF Class for operation Not EQUAL.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotNull GenericUDFOPNotNull.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNull GenericUDFOPNull.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPOr GenericUDF Class for computing or.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFRound Rounding function permits rounding off integer digits in decimal numbers, which essentially downgrades the scale to negative territory.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFRpad UDFRpad.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFToUnixTimeStamp Deterministic version of UDFUnixTimeStamp.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils Util functions for GenericUDF classes.
org.apache.hadoop.hive.ql.udf.generic.NumDistinctValueEstimator Take the average of the index for all the bit vectors and get the estimated NDV (estimateNumDistinctValues).
org.apache.hadoop.hive.ql.udf.generic.NumericHistogram A generic, re-usable histogram class that supports partial aggregations.
org.apache.hadoop.hive.ql.udf.generic.RoundUtils Utility class for generic round UDF.
org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction A window function performs a calculation across a set of table rows that are somehow related to the current row.
org.apache.hadoop.hive.ql.util.DateTimeMath Operations involving/returning year-month intervals.
org.apache.hadoop.hive.ql.util.DosToUnix Converting windows script to UNIX.
org.apache.hadoop.hive.ql.util.ZooKeeperHiveHelper Get the ensemble server addresses from the configuration. The format is: host1:port,host2:port
org.apache.hadoop.hive.serde2.AbstractSerDe Abstract class for implementing SerDe.
org.apache.hadoop.hive.serde2.ColumnProjectionUtils ColumnProjectionUtils.
org.apache.hadoop.hive.serde2.DelimitedJSONSerDe DelimitedJSONSerDe.
org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe MetadataTypedColumnsetSerDe.
org.apache.hadoop.hive.serde2.OpenCSVSerde OpenCSVSerde use opencsv to deserialize CSV format.
org.apache.hadoop.hive.serde2.RegexSerDe RegexSerDe uses regular expression (regex) to deserialize data.
org.apache.hadoop.hive.serde2.SerDeUtils SerDeUtils.
org.apache.hadoop.hive.serde2.WriteBuffers The structure storing arbitrary amount of data as a set of fixed-size byte buffers.
org.apache.hadoop.hive.serde2.avro.AvroLazyObjectInspector Lazy objectinspector for avro serialization
org.apache.hadoop.hive.serde2.avro.AvroSerDe Read or write Avro data from Hive.
org.apache.hadoop.hive.serde2.avro.AvroSerdeUtils Utilities useful only to the AvroSerde itself.
org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe BinarySortableSerDe can be used to write data in a way that the data can be compared byte-by-byte with the same order.
org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableDeserializeRead Directly deserialize with the caller reading field-by-field the LazyBinary serialization format.
org.apache.hadoop.hive.serde2.binarysortable.fast.BinarySortableSerializeWrite Directly serialize, field-by-field, the BinarySortable format.
org.apache.hadoop.hive.serde2.io.DateWritable DateWritable Writable equivalent of java.sql.Date.
org.apache.hadoop.hive.serde2.io.HiveDecimalWritable Get a HiveDecimal instance from the writable and constraint it with maximum precision/scale.
org.apache.hadoop.hive.serde2.io.TimestampWritable TimestampWritable Writable equivalent of java.sq.Timestamp Timestamps are of the format YYYY-MM-DD HH:MM:SS.[fff...] We encode Unix timestamp in seconds in 4 bytes, using the MSB to signify whether the timestamp has a fractional portion.
org.apache.hadoop.hive.serde2.lazy.LazyBinary LazyBinary stores a binary object in a LazyObject.
org.apache.hadoop.hive.serde2.lazy.LazyHiveDecimal LazyHiveDecimal stores hive decimal object in LazyObject.
org.apache.hadoop.hive.serde2.lazy.LazyMap LazyMap stores a map of Primitive LazyObjects to LazyObjects.
org.apache.hadoop.hive.serde2.lazy.LazySerDeParameters SerDeParameters.
org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe LazySimpleSerDe can be used to read the same data format as MetadataTypedColumnsetSerDe and TCTLSeparatedProtocol.
org.apache.hadoop.hive.serde2.lazy.LazyUtils LazyUtils.
org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleDeserializeRead Directly deserialize with the caller reading field-by-field the LazySimple (text) serialization format.
org.apache.hadoop.hive.serde2.lazy.fast.LazySimpleSerializeWrite Directly serialize, field-by-field, the LazyBinary format.
org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector LazyListObjectInspector works on array data that is stored in LazyArray.
org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector LazyMapObjectInspector works on struct data that is stored in LazyStruct.
org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector LazyUnionObjectInspector works on union data that is stored in LazyUnion.
org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe The LazyBinarySerDe class combines the lazy property of LazySimpleSerDe class and the binary property of BinarySortable class.
org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinaryDeserializeRead Directly deserialize with the caller reading field-by-field the LazyBinary serialization format.
org.apache.hadoop.hive.serde2.lazybinary.fast.LazyBinarySerializeWrite Directly serialize, field-by-field, the LazyBinary format.
org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector ReflectionStructObjectInspector works on struct data that is stored as a native Java object.
org.apache.hadoop.hive.serde2.objectinspector.SettableUnionObjectInspector SettableUnionObjectInspector.
org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector ListStructObjectInspector works on struct data that is stored as a Java List or Java Array object.
org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector StandardUnionObjectInspector works on union data that is stored as UnionObject.
org.apache.hadoop.hive.serde2.objectinspector.ThriftUnionObjectInspector Always use the ObjectInspectorFactory to create new ObjectInspector objects, instead of directly creating an instance of this class.
org.apache.hadoop.hive.serde2.typeinfo.HiveDecimalUtils Utilities for decimal precision and scale.
org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils TypeInfoUtils.
org.apache.hadoop.hive.shims.Hadoop23Shims Implemention of shims against Hadoop 0.23.0.
org.apache.hadoop.hive.shims.HadoopShimsSecure Base implemention for shims against secure Hadoop 0.20.3/0.23.
org.apache.hadoop.hive.shims.ShimLoader ShimLoader.
org.apache.hadoop.hive.shims.Utils Utilities for split location provider.
org.apache.hadoop.hive.thrift.DelegationTokenSecretManager A Hive specific delegation token secret manager.
org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge Functions that bridge Thrift's SASL transports to Hadoop's SASL callback handlers and authentication classes.
org.apache.hadoop.hive.thrift.TokenStoreDelegationTokenSecretManager Extension of DelegationTokenSecretManager to support alternative to default in-memory token management for fail-over and clustering through plug-able token store (ZooKeeper etc.).
org.apache.hive.beeline.BeeLine A console SQL shell with command completion.
org.apache.hive.beeline.Commands Implementation of beeline commands.
org.apache.hive.common.util.BloomFilter BloomFilter is a probabilistic data structure for set membership check.
org.apache.hive.common.util.DateUtils DateUtils.
org.apache.hive.common.util.HiveStringUtils HiveStringUtils General string utils Originally copied from o.a.hadoop.util.StringUtils
org.apache.hive.common.util.HiveTestUtils Utilities for testing hive.
org.apache.hive.common.util.Murmur3 Murmur3 is successor to Murmur2 fast non-crytographic hash algorithms.
org.apache.hive.common.util.ShutdownHookManager The ShutdownHookManager enables running shutdownHook in a deterministic order, higher priority first.
org.apache.hive.common.util.StreamPrinter StreamPrinter.
org.apache.hive.hcatalog.cli.HCatCli HCatalog command line interface.
org.apache.hive.hcatalog.common.HCatConstants List of constants used by HCatalog.
org.apache.hive.hcatalog.streaming.ConnectionError Exception to catch connection errors.
org.apache.hive.hcatalog.streaming.DelimitedInputWriter Streaming Writer handles delimited input (eg.
org.apache.hive.hcatalog.streaming.HiveEndPoint Information about the hive end point (i.e.
org.apache.hive.hcatalog.streaming.InvalidTable Exception to catch invalid table.
org.apache.hive.hcatalog.streaming.StrictJsonWriter Streaming Writer handles utf8 encoded Json (Strict syntax).
org.apache.hive.hcatalog.templeton.AppConfig The configuration for Templeton.
org.apache.hive.hcatalog.templeton.Main The main executable that starts up and runs the Server.
org.apache.hive.jdbc

.HiveConnection

HiveConnection.
org.apache.hive.jdbc

.HiveDatabaseMetaData

HiveDatabaseMetaData.
org.apache.hive.jdbc

.HivePreparedStatement

HivePreparedStatement.
org.apache.hive.jdbc

.HiveQueryResultSet

HiveQueryResultSet.
org.apache.hive.jdbc

.HiveStatement

HiveStatement.
org.apache.hive.jdbc

.JdbcColumn

Column metadata.
org.apache.hive.jdbc

.Utils

Utilities for jdbc.
org.apache.hive.service.ServiceUtils Utilities to correctly process domain names etc.
org.apache.hive.service.auth.AuthenticationProviderFactory Helps select a PasswdAuthenticationProvider for a given {@code AuthMethod}.
org.apache.hive.service.auth.HiveAuthFactory Helps in some aspects of authentication.
org.apache.hive.service.auth.LdapAuthenticationProviderImpl Utilities to correctly process domain names etc.
org.apache.hive.service.auth.TSetIpAddressProcessor Sets the ipAddress for operations executed via HiveServer2.
org.apache.hive.service.cli.CLIService CLIService.
org.apache.hive.service.cli.CLIServiceUtils CLIServiceUtils.
org.apache.hive.service.cli.ColumnBasedSet ColumnBasedSet.
org.apache.hive.service.cli.ColumnDescriptor ColumnDescriptor.
org.apache.hive.service.cli.ColumnValue Protocols before HIVE_CLI_SERVICE_PROTOCOL_V6 (used by RowBasedSet)
org.apache.hive.service.cli.EmbeddedCLIServiceClient Embedded CLI Service Client.
org.apache.hive.service.cli.FetchOrientation Fetch Orientation.
org.apache.hive.service.cli.GetInfoType Get Info type.
org.apache.hive.service.cli.GetInfoValue Get Info value.
org.apache.hive.service.cli.Handle Handle.
org.apache.hive.service.cli.HandleIdentifier Handle identifier.
org.apache.hive.service.cli.HiveSQLException Hive SQL exception.
org.apache.hive.service.cli.OperationHandle Handler for operation.
org.apache.hive.service.cli.OperationState Operation State.
org.apache.hive.service.cli.OperationStatus Operation Status.
org.apache.hive.service.cli.OperationType OperationType.
org.apache.hive.service.cli.RowBasedSet Row Based Set.
org.apache.hive.service.cli.RowSetFactory Row set factory class.
org.apache.hive.service.cli.SessionHandle Session Handle.
org.apache.hive.service.cli.TableSchema Table Schema.
org.apache.hive.service.cli.TypeDescriptor Type Descriptor.
org.apache.hive.service.cli.TypeQualifiers Holds type qualifier information for a primitive type, such as char/varchar length or decimal precision/scale.
org.apache.hive.service.cli.operation.ClassicTableTypeMapping Classic Table Type Mapping.
org.apache.hive.service.cli.operation.ExecuteStatementOperation Implementation of statement execution.
org.apache.hive.service.cli.operation.HiveCommandOperation Executes a HiveCommand.
org.apache.hive.service.cli.operation.HiveTableTypeMapping Hive Table Type Mapping.
org.apache.hive.service.cli.operation.LogDivertAppender Divert appender to redirect operation logs to separate files.
org.apache.hive.service.cli.operation.MetadataOperation Metadata Operation.
org.apache.hive.service.cli.operation.Operation Class to define operation.
org.apache.hive.service.cli.operation.OperationManager Operation Manager.
org.apache.hive.service.cli.operation.SQLOperation SQL Operation.
org.apache.hive.service.cli.session.HiveSessionImpl Hive Session.
org.apache.hive.service.cli.session.HiveSessionImplwithUGI Hive session implementation with UGI.
org.apache.hive.service.cli.session.SessionManager Session Manager.
org.apache.hive.service.cli.thrift.ThriftBinaryCLIService Initialize worker threads in hive CLI startup.
org.apache.hive.service.cli.thrift.ThriftCLIService Thrift CLI Service.
org.apache.hive.service.cli.thrift.ThriftCLIServiceClient Thrift CLI Service Client.
org.apache.hive.service.cli.thrift.ThriftHttpCLIService Service to handle requests over HTTP.
org.apache.hive.service.cli.thrift.ThriftHttpServlet Thrift Http servlet.
org.apache.hive.spark.client.MetricsCollection Provides metrics collected for a submitted job.
org.apache.hive.spark.client.SparkClientUtilities Utilities for spark client.
org.apache.hive.spark.client.rpc.Rpc Encapsulates the RPC functionality.
org.apache.hive.spark.client.rpc.RpcConfiguration Definitions of configuration keys and default values for the RPC layer.
org.apache.hive.spark.client.rpc.RpcServer An RPC server.