New Classes in Hive 2.1

Hive 2.1 includes the following new classes:

Class Description
org.apache.hadoop.hive.common.DiskRangeInfo Contains disk range information including disk ranges and total length.
org.apache.hadoop.hive.common.JvmPauseMonitor This is based on the JvmPauseMonitor from Hadoop.

org.apache.hadoop.hive.common.StringableMap

A utility class that can convert a HashMap of Properties into a colon separated string, and can take the same format of string and convert it to a HashMap of Properties.

org.apache.hadoop.hive.common.ValidCompactorTxnList

An implementation of org.apache.hadoop.hive.common.ValidTxnList for use by the compactor.
org.apache.hadoop.hive.common.io

.DiskRange

The sections of a file.
org.apache.hadoop.hive.common.io.DiskRangeList Alternative for Java linked list iterator interface to support concurrent modifications of the same list by multiple iterators.
org.apache.hadoop.hive.common.jsonexplain.tez.Printer Creation of output string to show JSON plan.
org.apache.hadoop.hive.common.jsonexplain.tez.TezJsonParserUtils JsonParser for Tez that prints a JSONObject nto outputStream.
org.apache.hadoop.hive.common.metrics.LegacyMetrics The Metrics Subsystem allows exposure of a number of named parameters/counters via JMX, is intended to be used as a static subsystem, and has a couple of primary ways in which it can be used:
  • Using the set and get methods to set and get named parameters.
  • Using the incrementCounter method to increment and set named parameters in one go, rather than having to make a get and then a set.
  • Using the startScope and endScope methods to start and end named "scopes" that record the number of times they have been instantiated and amount of time (in milliseconds) spent inside the scopes.
org.apache.hadoop.hive.common.type.RandomTypeUtil Creates random data of different object types.
org.apache.hadoop.hive.conf.VariableSubstitution Substitution of environment variables.
org.apache.hadoop.hive.contrib.genericudf.example.GenericUDFAdd10 Intializes the GenericUDF (once per instance), evaluates the GenericUDF with the arguments, and gets the string to display.
org.apache.hadoop.hive.io.HdfsUtils Utils to resolve file properties in MAPR filesystem.
org.apache.hadoop.hive.metastore.AcidEventListener It handles cleanup of dropped partition/table/database in ACID related metastore tables.
org.apache.hadoop.hive.metastore.FileMetadataHandler The base implementation of a file metadata handler for a specific file type.
org.apache.hadoop.hive.metastore.FileMetadataManager Handle storage functions of metadata.
org.apache.hadoop.hive.metastore.HMSMetricsListener Report metrics of metadata added and deleted by this Hive Metastore.
org.apache.hadoop.hive.metastore.Metastore Class to arrange work with Metastore.
org.apache.hadoop.hive.metastore.PartFilterExprUtil Utility functions for working with partition filter expressions.
org.apache.hadoop.hive.metastore.api.AbortTxnsRequest Class for handling transactions request.
org.apache.hadoop.hive.metastore.api.AddForeignKeyRequest Class for handling foreign key request.
org.apache.hadoop.hive.metastore.api.AddPrimaryKeyRequest Class for handling primary key request.
org.apache.hadoop.hive.metastore.api.CacheFileMetadataRequest Class for caching metadata requests.
org.apache.hadoop.hive.metastore.api.CacheFileMetadataResult Class for caching metadata results.
org.apache.hadoop.hive.metastore.api.ClearFileMetadataResult Class for clearing metadata results.
org.apache.hadoop.hive.metastore.api.DropConstraintRequest Class for dropping constraint requests.
org.apache.hadoop.hive.metastore.api.ForeignKeysRequest Class for handling foreign key requests.
org.apache.hadoop.hive.metastore.api.ForeignKeysResponse Class for getting response from all functions.
org.apache.hadoop.hive.metastore.api.GetAllFunctionsResponse Class for getting response from all functions.
org.apache.hadoop.hive.metastore.api.GetFileMetadataByExprRequest Class for getting metadata from expression response.
org.apache.hadoop.hive.metastore.api.GetFileMetadataByExprResult Class for getting metadata from expression result.
org.apache.hadoop.hive.metastore.api.MetadataPpdResult Class for describing metadata rpd result.
org.apache.hadoop.hive.metastore.api.PrimaryKeysRequest Class for describing primary key result.
org.apache.hadoop.hive.metastore.api.PrimaryKeysResponse Class for describing primary key response.
org.apache.hadoop.hive.metastore.api.PutFileMetadataRequest Class for output metadata request to file.
org.apache.hadoop.hive.metastore.api.PutFileMetadataResult Class for output metadata result to file.
org.apache.hadoop.hive.metastore.api.SQLForeignKey Class for describing SQL foreign key.
org.apache.hadoop.hive.metastore.api.SQLPrimaryKey Class for describing SQL primary key.
org.apache.hadoop.hive.metastore.api.TableMeta Class for describing table metadata.
org.apache.hadoop.hive.metastore.model.MConstraint Model of constraints stored in metastore.
org.apache.hadoop.hive.metastore.txn.TxnUtils Class for handling transactions.
org.apache.hadoop.hive.ql.CompilationOpContext Contains the operator sequence ID and a subset of compilation context that is passed to operators to get rid of some globals.
org.apache.hadoop.hive.ql.QueryDisplay Contains limited query information to save for WebUI. The class is synchronized, as WebUI may access information about a running query.
org.apache.hadoop.hive.ql.QueryState The class to store query level info such as queryId.
org.apache.hadoop.hive.ql.exec.AbstractMapOperator Abstract Map operator.
org.apache.hadoop.hive.ql.exec.GlobalWorkMapFactory Get job that has been executed on cluster as a map value.
org.apache.hadoop.hive.ql.exec.ObjectCacheWrapper Wapping class for ObjectCache class.
org.apache.hadoop.hive.ql.exec.SerializationUtilities Utilities related to serialization and deserialization.
org.apache.hadoop.hive.ql.exec.UDFClassLoader UDFClassLoader is used to dynamically register udf (and related) jars. This was introducted to fix HIVE-11878. Each session will have its own instance of UDFClassLoader to support HiveServer2, which can contain multiple active sessions.
org.apache.hadoop.hive.ql.exec.spark.CacheTran Class for making cache persistent.
org.apache.hadoop.hive.ql.exec.spark.SmallTableCache Class for cache cleaning if new query is present.
org.apache.hadoop.hive.ql.exec.spark.SparkDynamicPartitionPruner The spark version of DynamicPartitionPruner.
org.apache.hadoop.hive.ql.exec.spark.status.impl.SparkJobUtils Utilities for spark job.
org.apache.hadoop.hive.ql.exec.tez.ColumnarSplitSizeEstimator Split size estimator for columnar file formats.
org.apache.hadoop.hive.ql.exec.tez.HostAffinitySplitLocationProvider This maps a split (path + offset) to an index based on the number of locations provided.
org.apache.hadoop.hive.ql.exec.tez.InPlaceUpdates Class responsible for inplace updates.
org.apache.hadoop.hive.ql.exec.tez.KeyValuesFromKeyValue Provides a key/values (note the plural values) interface out of a KeyValueReader, needed by ReduceRecordSource when reading input from a key/value source.
org.apache.hadoop.hive.ql.exec.tez.KeyValuesFromKeyValues Provides a key/values interface out of a KeyValuesReader for use by ReduceRecordSource.
org.apache.hadoop.hive.ql.exec.tez.LlapObjectCache Llap implementation for the shared object cache.
org.apache.hadoop.hive.ql.exec.tez.Utils Utilities for running tez jobs.
org.apache.hadoop.hive.ql.exec.vector.IntervalDayTimeColumnVector This class represents a nullable interval day time column vector capable of handing a wide range of interval day time values.
org.apache.hadoop.hive.ql.exec.vector.ListColumnVector The representation of a vectorized column of list objects.
org.apache.hadoop.hive.ql.exec.vector.MapColumnVector The representation of a vectorized column of map objects.
org.apache.hadoop.hive.ql.exec.vecto.MultiValuedColumnVector The representation of a vectorized column of multi-valued objects, such as lists and maps.
org.apache.hadoop.hive.ql.exec.vector.StructColumnVector The representation of a vectorized column of struct objects.
org.apache.hadoop.hive.ql.exec.vector.TimestampColumnVector This class represents a nullable timestamp column vector capable of handing a wide range of timestamp values.
org.apache.hadoop.hive.ql.exec.vector.UnionColumnVector The representation of a vectorized column of struct objects.
org.apache.hadoop.hive.ql.exec.vector.VectorSparkHashTableSinkOperator Vectorized version of SparkHashTableSinkOperator. It delegates all the work to super class Copied from VectorFileSinkOperator.
org.apache.hadoop.hive.ql.exec.vector.VectorSparkPartitionPruningSinkOperator Vectorized version for SparkPartitionPruningSinkOperator.
org.apache.hadoop.hive.ql.exec.vector.expressions.BRoundWithNumDigitsDoubleToDouble Banking rounding implementation.
org.apache.hadoop.hive.ql.exec.vector.expressions.CastDoubleToTimestamp Cast double type to timestamp type.
org.apache.hadoop.hive.ql.exec.vector.expressions.CastLongToTimestamp Cast long type to timestamp type.
org.apache.hadoop.hive.ql.exec.vector.expressions.CastMillisecondsLongToTimestamp Cast milliseconds long type to timestamp.
org.apache.hadoop.hive.ql.exec.vector.expressions.CastStringGroupToString Cast string group type to string type.
org.apache.hadoop.hive.ql.exec.vector.expressions.CastTimestampToBoolean Cast timestamp type to boolean.
org.apache.hadoop.hive.ql.exec.vector.expressions.CastTimestampToDate Cast timestamp type to decimal type.
org.apache.hadoop.hive.ql.exec.vector.expressions.CastTimestampToDouble Cast timestamp type to double type.
org.apache.hadoop.hive.ql.exec.vector.expressions.CastTimestampToLong Cast timestamp type to long type.
org.apache.hadoop.hive.ql.exec.vector.expressions.DateColSubtractDateColumn Substract two variables of date type.
org.apache.hadoop.hive.ql.exec.vector.expressions.DateColSubtractDateScalar Substract two variables of date type.
org.apache.hadoop.hive.ql.exec.vector.expressions.DateScalarSubtractDateColumn Substract two variables of date type.
org.apache.hadoop.hive.ql.exec.vector.expressions.FilterStructColumnInList Evaluates an IN filter on a batch for a vector of structs.
org.apache.hadoop.hive.ql.exec.vector.expressions.FilterTimestampColumnInList Evaluates IN filter on a batch for a vector of timestamps.
org.apache.hadoop.hive.ql.exec.vector.expressions.FuncBRoundWithNumDigitsDecimalToDecimal Banking rounding for decimal digits.
org.apache.hadoop.hive.ql.exec.vector.expressions.FuncDecimalToTimestamp This is a superclass for unary decimal functions and expressions returning timestamps that operate directly on the input and set the output.
org.apache.hadoop.hive.ql.exec.vector.expressions.FuncTimestampToDecimal This is a superclass for unary timestamp functions and expressions returning decimals that operate directly on the input and set the output.
org.apache.hadoop.hive.ql.exec.vector.expressions.FuncTimestampToLong This is a superclass for unary timestamp functions and expressions returning long that operate directly on the input and set the output.
org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprDoubleColumnDoubleColumn Computes IF(expr1, expr2, expr3) for 3 input column expressions.
org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprIntervalDayTimeColumnColumn Computes IF(expr1, expr2, expr3) for 3 input column expressions.
org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprIntervalDayTimeColumnScalar Computes IF(expr1, expr2, expr3) for 3 input column expressions.
org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprIntervalDayTimeScalarColumn Computes IF(expr1, expr2, expr3) for 3 input column expressions.
org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprIntervalDayTimeScalarScalar Computes IF(expr1, expr2, expr3) for 3 input column expressions.
org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprLongColumnLongColumn Computes IF(expr1, expr2, expr3) for 3 input column expressions.
org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprTimestampColumnColumn Computes IF(expr1, expr2, expr3) for 3 input column expressions.
org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprTimestampColumnColumnBase Computes IF(expr1, expr2, expr3) for 3 input column expressions.
org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprTimestampColumnScalar Computes IF(expr1, expr2, expr3) for 3 input column expressions.
org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprTimestampColumnScalarBase Computes IF(expr1, expr2, expr3) for 3 input column expressions.

org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprTimestampScalarColumn

Computes IF(expr1, expr2, expr3) for 3 input column expressions.
org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprTimestampScalarColumnBase Computes IF(expr1, expr2, expr3) for 3 input column expressions.
org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprTimestampScalarScalar Computes IF(expr1, expr2, expr3) for 3 input column expressions.
org.apache.hadoop.hive.ql.exec.vector.expressions.IfExprTimestampScalarScalarBase Computes IF(expr1, expr2, expr3) for 3 input column expressions.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongColEqualLongColumn If equal two columns as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongColEqualLongScalar If equal long column and long scalar as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongColGreaterEqualLongColumn If greater or equal two columns as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongColGreaterEqualLongScalar If greater or equal long column and long scalar.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongColGreaterLongColumn If greater two columns as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongColGreaterLongScalar If greater long column and long scalar as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongColLessEqualLongColumn If less equal two columns as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongColLessEqualLongScalar If less equal long column and long scalar as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongColLessLongColumn If less two columns as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongColLessLongScalar If less long column and long scalar as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongColNotEqualLongColumn If not equal two columns as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongColNotEqualLongScalar If not equal long column and long scalar as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarEqualLongColumn If equal long scalar and long column.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarGreaterEqualLongColumn If greater equal long scalar and long column as vector.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarGreaterLongColumn If greater long scalar and long column as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarLessEqualLongColumn If less equal long scalar and long column as vector.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarLessLongColumn If less long scalar and long column as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.LongScalarNotEqualLongColumn If not equal long scalar and long column as vectors.
org.apache.hadoop.hive.ql.exec.vector.expressions.SelectStringColLikeStringScalar Select like statement for string column and string scalar.
org.apache.hadoop.hive.ql.exec.vector.expressions.StructColumnInList Evaluates an IN boolean expression (not a filter) on a batch for a vector of structs.
org.apache.hadoop.hive.ql.exec.vector.expressions.TimestampColumnInList Returns a boolean value indicating if a column is IN a list of constants.
org.apache.hadoop.hive.ql.exec.vector.expressions.TimestampToStringUnaryUDF This is a superclass for unary long functions returning strings that operate directly on the input and set the output.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDateTimestamp Vectorized version of TO_DATE(timestamp).
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDayOfMonthDate Expression to get day of month.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFDayOfMonthTimestamp Expression to get day of month.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFHourDate Returns hour of day.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFHourTimestamp Returns hour of day.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMinuteDate Returns minute value.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMinuteTimestamp Returns minute value.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMonthDate Returns month value.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFMonthTimestamp Returns month value.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFSecondDate Expression to get seconds.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFSecondTimestamp Expression to get seconds.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldDate Abstract class to return various fields from a Timestamp or Date.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFTimestampFieldTimestamp Abstract class to return various fields from a Timestamp.

org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFUnixTimeStampDate

Returns Unix Timestamp.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFUnixTimeStampTimestamp Returns Unix Timestamp.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFWeekOfYearDate Expression to get week of year.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFWeekOfYearTimestamp Expression to get week of year.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFYearDate Expression to get year as a long.
org.apache.hadoop.hive.ql.exec.vector.expressions.VectorUDFYearTimestamp Expression to get year as a long.
org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFAvgTimestamp Generated from template VectorUDAFAvg.txt.
org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFStdPopTimestamp Vectorized implementation for VARIANCE aggregates.
org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFStdSampTimestamp Vectorized implementation for VARIANCE aggregates.
org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFVarPopTimestamp Vectorized implementation for VARIANCE aggregates.
org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorUDAFVarSampTimestamp Vectorized implementation for VARIANCE aggregates.
org.apache.hadoop.hive.ql.hooks.LineageLogger Implementation of a post execute hook that logs lineage info to a log file.
org.apache.hadoop.hive.ql.hooks.PostExecOrcFileDump Post execution hook to print orc file dump for files that will be read by fetch task.
org.apache.hadoop.hive.ql.hooks.PostExecTezSummaryPrinter Post execution hook to print hive tez counters to console error stream.
org.apache.hadoop.hive.ql.io.HdfsUtils Utilities for hadoop fs.
org.apache.hadoop.hive.ql.io.IOContextMap Uses the global static map of IOContext-s inside IOContext, uses threadlocal for Spark, and creates inheritable threadlocal with attemptId (only set in LLAP), which will propagate to all the Tez threads.
org.apache.hadoop.hive.ql.io.NullScanFileSystem Filesystem that does not allow Hive to read files for nullscans.
org.apache.hadoop.hive.ql.io.ProxyLocalFileSystem This class is to workaround existing issues on LocalFileSystem.
org.apache.hadoop.hive.ql.io.SyntheticFileId Create synthetic ID for file.
org.apache.hadoop.hive.ql.io.orc.ExternalCache Metastore-based footer cache storing serialized footers.
org.apache.hadoop.hive.ql.io.orc.MetastoreExternalCachesByConf An implementation of external cache and factory based on metastore.
org.apache.hadoop.hive.ql.io.orc.OrcFileFormatProxy File format proxy for ORC.
org.apache.hadoop.hive.ql.io.orc.RecordReaderImpl Implementation of record reader.
org.apache.hadoop.hive.ql.io.parquet.read.ParquetFilterPredicateConverter

Translate the search argument to the filter predicate parquet uses.

org.apache.hadoop.hive.ql.io.sarg.ConvertAstToSearchArg Converting asterisk and use it as a search argument.
org.apache.hadoop.hive.ql.io.sarg.SearchArgumentImpl The implementation of SearchArguments.
org.apache.hadoop.hive.ql.lib.PreOrderOnceWalker This class takes list of starting nodes and walks them in pre-order.
org.apache.hadoop.hive.ql.log.HiveEventCounter A log4J2 appender that simply counts logging events in four levels: fatal, error, warn, and info.
org.apache.hadoop.hive.ql.log.NoDeleteRollingFileAppender Instantiate a RollingFileAppender and open the file designated by filename. The opened filename will become the output destination for this appender.
org.apache.hadoop.hive.ql.log.NullAppender A NullAppender that never outputs a message to any device.
org.apache.hadoop.hive.ql.log.PidFilePatternConverter FilePattern converter that converts %pid pattern to @ information obtained at runtime.
org.apache.hadoop.hive.ql.metadata.ForeignKeyInfo ForeignKeyInfo is a metadata structure containing the foreign keys associated with a table.
org.apache.hadoop.hive.ql.metadata.PrimaryKeyInfo PrimaryKeyInfo is a metadata structure containing the primary key associated with a table.
org.apache.hadoop.hive.ql.metadata.TableIterable Gets Table objects for a table list.
org.apache.hadoop.hive.ql.optimizer.OperatorComparatorFactory Comparator for table operators.
org.apache.hadoop.hive.ql.optimizer.PartitionColumnsSeparator Takes a Filter expression, and if its predicate contains an IN operator whose children are constant structs or structs containing constant fields, it will try to generate predicate with IN clauses containing only partition columns.
org.apache.hadoop.hive.ql.optimizer.PointLookupOptimizer Takes a Filter expression, and if its predicate contains an OR operator whose children are constant equality expressions, it will try to generate an IN clause (which is more efficient).
org.apache.hadoop.hive.ql.optimizer.RedundantDynamicPruningConditionsRemoval Takes a Filter operator on top of a TableScan and removes dynamic pruning conditions if static partition pruning has been triggered already.
org.apache.hadoop.hive.ql.optimizer.SparkRemoveDynamicPruningBySize Disables pruning if the number of keys for dynamic pruning is too large.
org.apache.hadoop.hive.ql.optimizer.calcite.HivePlannerContext Creating context for Hive Planner.
org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelBuilder Builder for relational expressions in Hive.
org.apache.hadoop.hive.ql.optimizer.calcite.HiveRelFactories Factory class for creating relational operators for queries.
org.apache.hadoop.hive.ql.optimizer.calcite.HiveRexExecutorImpl Hive registry executor implementation.
org.apache.hadoop.hive.ql.optimizer.calcite.HiveRexUtil Utilities for hive registry executor.
org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveBetween Operand type-inference strategy where an unknown operand type is derived from the first operand with a known type, but the first operand is a boolean.
org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveIn Create in clause instance for hive queries.
org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveMultiJoin A HiveMultiJoin represents a succession of binary joins.
org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSortLimit Sorting limit in hive queries.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveAggregateJoinTransposeRule Planner rule that pushes an org.apache.calcite.rel.core.Aggregate past a org.apache.calcite.rel.core.Join.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveAggregateProjectMergeRule Planner rule that recognizes a HiveAggregate on top of a HiveProject and if possible, aggregates through the project or removes the project.

org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveAggregatePullUpConstantsRule

Rule for pull up constants aggregation.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterAggregateTransposeRule Transpose rule for filter aggregation.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterProjectTSTransposeRule Transpose rule for filtering project TST.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveFilterSortTransposeRule Transpose rule for filtering sort.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveJoinProjectTransposeRule Transpose rule for join project.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HivePointLookupOptimizerRule Takes a Filter expression, and if its predicate contains an OR operator whose children are constant equality expressions, tries to generate an IN clause (which is more efficient).
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveProjectFilterPullUpConstantsRule Planner rule that infers constant expressions from Filter into a Project operator.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveProjectSortTransposeRule Transpose rule for project sort.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveReduceExpressionsRule Collection of planner rules that apply various simplifying transformations on RexNode trees.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveReduceExpressionsWithStatsRule This rule simplifies the condition in Filter operators using the column statistics (if available).
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveRelColumnsAlignment Infers the order in Aggregate columns and the order of conjuncts in a Join condition that might be more beneficial to avoid additional sort stages.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveSortJoinReduceRule Planner rule that pushes a org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSortLimit past a org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveJoin.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveSortLimitPullUpConstantsRule Planner rule that pulls up constant keys through a SortLimit operator.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveSortMergeRule This rule will merge two HiveSortLimit operators.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveSortProjectTransposeRule Transpose rule for sort project.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveSortRemoveRule Planner rule that removes a org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSortLimit.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveSortUnionReduceRule Planner rule that pushes a org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveSortLimit past aorg.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveUnion.
org.apache.hadoop.hive.ql.optimizer.calcite.rules.HiveUnionPullUpConstantsRule Planner rule that pulls up constants through a Union operator.
org.apache.hadoop.hive.ql.optimizer.calcite.stats.HiveRelMdPredicates Infers predicates for a project.
org.apache.hadoop.hive.ql.optimizer.physical.LlapDecider LlapDecider takes care of tagging certain vertices in the execution graph as "llap", which in turn causes them to be submitted to an llap daemon instead of a regular yarn container.
org.apache.hadoop.hive.ql.optimizer.physical.MemoryDecider MemoryDecider is a simple physical optimizer that adjusts the memory layout of tez tasks.
org.apache.hadoop.hive.ql.optimizer.physical.SerializeFilter SerializeFilter is a simple physical optimizer that serializes all filter expressions in Tablescan Operators.
org.apache.hadoop.hive.ql.optimizer.spark.CombineEquivalentWorkResolver CombineEquivalentWorkResolver searches inside SparkWork, finds and combines equivalent works.
org.apache.hadoop.hive.ql.optimizer.spark.SparkPartitionPruningSinkDesc Description of spark partition pruning sink.
org.apache.hadoop.hive.ql.parse.AnalyzeCommandUtils Utilities for command analysis.
org.apache.hadoop.hive.ql.parse.ColumnStatsAutoGatherContext ColumnStatsAutoGatherContext is passed to the compiler when set hive.stats.autogather is true during the INSERT OVERWRITE command.
org.apache.hadoop.hive.ql.parse.MaskAndFilterInfo Information for masking and filtering.
org.apache.hadoop.hive.ql.parse.TableMask The main purpose for this class is for authorization.
org.apache.hadoop.hive.ql.parse.spark.SparkPartitionPruningSinkOperator This operator gets partition info from the upstream operators and writes them to HDFS.
org.apache.hadoop.hive.ql.parse.spark.SplitOpTreeForDPP This processor triggers on SparkPartitionPruningSinkOperator.
org.apache.hadoop.hive.ql.plan.AbortTxnsDesc Descriptor for aborting transactions.
org.apache.hadoop.hive.ql.plan.CacheMetadataDesc Description for metadata cache.
org.apache.hadoop.hive.ql.plan.ShowCreateDatabaseDesc Shows the name of the database.
org.apache.hadoop.hive.ql.plan.VectorPartitionConversion PartitionConversion.
org.apache.hadoop.hive.ql.plan.VectorPartitionDesc VectorMapDesc.
org.apache.hadoop.hive.ql.plan.VectorReduceSinkDesc VectorReduceSinkDesc.
org.apache.hadoop.hive.ql.plan.VectorReduceSinkInfo VectorGroupByAggregrationInfo.
org.apache.hadoop.hive.ql.ppd.SimplePredicatePushDown Implementation of predicate push down.
org.apache.hadoop.hive.ql.security.authorization.DefaultHiveAuthorizationTranslator Default implementation of HiveAuthorizationTranslator.
org.apache.hadoop.hive.ql.security.authorization.plugin.AbstractHiveAuthorizer Abstract class that extends HiveAuthorizer.
org.apache.hadoop.hive.ql.session.ClearDanglingScratchDir A tool to remove dangling scratch directory.
org.apache.hadoop.hive.ql.stats.StatsCollectionContext Creating context for stats collection.
org.apache.hadoop.hive.ql.txn.compactor.HouseKeeperServiceBase Housekeeper for running services.
org.apache.hadoop.hive.ql.udf.UDFChr UDFChr converts an integer into its ASCII equivalent.
org.apache.hadoop.hive.ql.udf.UDFCrc32 UDFCrc32.
org.apache.hadoop.hive.ql.udf.UDFMd5 UDFMd5.
org.apache.hadoop.hive.ql.udf.UDFReplace UDFReplace replaces all substrings that are matched with a replacement substring.
org.apache.hadoop.hive.ql.udf.UDFSha1 UDFSha.
org.apache.hadoop.hive.ql.udf.UDFVersion UDFVersion
org.apache.hadoop.hive.ql.udf.generic.BaseMaskUDF User defined function for masking.
org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSumEmptyIsZero User defined aggregation function for summing empy as zeros.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFAesBase Base for user defined functions.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFAesDecrypt User defined function for decryption.

org.apache.hadoop.hive.ql.udf.generic.GenericUDFAesEncrypt

User defined function for encryption.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFBRound User defined function for banking rounding.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseNwayCompare Base class for comparison UDF's (Greatest and Least).
org.apache.hadoop.hive.ql.udf.generic.GenericUDFMask User defined function for masking.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFMaskFirstN User defined function for masking first n symbols.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFMaskHash User defined function that returns a hashed value based on str.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFMaskLastN User defined function for masking last n symbols.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFMaskShowFirstN User defined function for showing masked first n symbols.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFMaskShowLastN User defined function for showing masked last n symbols.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFParamUtils Generic UDF params utility class.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFQuarter GenericUDFQuarter.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFRegExp UDF to extract a specific group identified by a java regex.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFSha2 GenericUDFSha2.
org.apache.hadoop.hive.ql.udf.generic.GenericUDFSubstringIndex GenericUDFSubstringIndex.
org.apache.hadoop.hive.ql.udf.generic.GenericUDTFGetSplits GenericUDTFGetSplits.
org.apache.hadoop.hive.ql.util.DependencyResolver Query dependency resolver.
org.apache.hadoop.hive.ql.util.ResourceDownloader Resource downloader.
org.apache.hadoop.hive.ql.util.TimestampUtils Utitilities for Timestamps and the relevant conversions.
org.apache.hadoop.hive.serde2.DefaultFetchFormatter Serializes row by user specified serde and calls toString() to make string type result.
org.apache.hadoop.hive.serde2.NoOpFetchFormatter A No-op fetch formatter.
org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDeWithEndPrefix Serializer desrializer for binary sortable.
org.apache.hadoop.hive.serde2.thrift.ColumnBuffer Column buffer.
org.apache.hadoop.hive.serde2.thrift.ThriftFormatter Thrift formatter.
org.apache.hadoop.hive.serde2.thrift.ThriftJDBCBinarySerDe Serializes the final output to thrift-able objects directly in the SerDe.
org.apache.hadoop.hive.thrift.HiveDelegationTokenManager Delegation token manager.
org.apache.hive.beeline.ClientCommandHookFactory Updates some client side information after executing some Hive commands.
org.apache.hive.beeline.ClientHook This is the client's hook and used for new Hive CLI.
org.apache.hive.common.util.DateParser Date parser class for Hive.
org.apache.hive.common.util.FixedSizedObjectPool Simple object pool of limited size.
org.apache.hive.common.util.HashCodeUtil Utilities for hash code.
org.apache.hive.common.util.IntervalDayTimeUtils DateUtils.
org.apache.hive.hcatalog.streaming.AbstractRecordWriter Class for defining record writer.
org.apache.hive.jdbc.HttpTokenAuthInterceptor The class is instantiated with the username and password, it is then used to add header with these credentials to HTTP requests
org.apache.hive.jdbc.XsrfHttpRequestInterceptor Http request interceptor for xsrf token.
org.apache.hive.service.cli.operation.GetCrossReferenceOperation GetCrossReferenceOperation.
org.apache.hive.service.cli.operation.GetPrimaryKeysOperation GetPrimaryKeysOperation.
org.apache.hive.service.cli.operation.SQLOperationDisplay Used to display some info in the HS2 WebUI.
org.apache.hive.service.cli.operation.SQLOperationDisplayCache Cache some SQLOperation information for WebUI
org.apache.hive.service.cli.thrift.RetryingThriftCLIServiceClient RetryingThriftCLIServiceClient.